Skip to content

Commit

Permalink
Fix -Wunused-parameter (#13138)
Browse files Browse the repository at this point in the history
Devtools global refactoring
  • Loading branch information
vvd170501 authored Jan 8, 2025
1 parent e7c573f commit 6f59478
Show file tree
Hide file tree
Showing 33 changed files with 55 additions and 55 deletions.
8 changes: 4 additions & 4 deletions ydb/core/cms/console/console_handshake.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -29,14 +29,14 @@ class TConfigsManager::TConsoleCommitActor : public TActorBootstrapped<TConsoleC
Become(&TThis::StateWork);
}

void Handle(TEvConsole::TEvReplaceYamlConfigResponse::TPtr& ev) {
void Handle(TEvConsole::TEvReplaceYamlConfigResponse::TPtr& /* ev */) {
auto response = std::make_unique<TEvBlobStorage::TEvControllerConsoleCommitResponse>();
response->Record.SetStatus(NKikimrBlobStorage::TEvControllerConsoleCommitResponse::Committed);
SendInReply(SenderId, InterconnectSession, std::move(response));
PassAway();
}

void Handle(TEvConsole::TEvGenericError::TPtr& ev) {
void Handle(TEvConsole::TEvGenericError::TPtr& /* ev */) {
auto response = std::make_unique<TEvBlobStorage::TEvControllerConsoleCommitResponse>();
response->Record.SetStatus(NKikimrBlobStorage::TEvControllerConsoleCommitResponse::NotCommitted);
SendInReply(SenderId, InterconnectSession, std::move(response));
Expand Down Expand Up @@ -114,7 +114,7 @@ void TConfigsManager::Handle(TEvBlobStorage::TEvControllerProposeConfigRequest::
SendInReply(ev->Sender, ev->InterconnectSession, std::move(response));
}

void TConfigsManager::Handle(TEvBlobStorage::TEvControllerConsoleCommitRequest::TPtr &ev, const TActorContext &ctx) {
void TConfigsManager::Handle(TEvBlobStorage::TEvControllerConsoleCommitRequest::TPtr& ev, const TActorContext& /* ctx */) {
auto response = std::make_unique<TEvBlobStorage::TEvControllerConsoleCommitResponse>();
const auto& yamlConfig = ev->Get()->Record.GetYAML();
if (!CheckSession(*ev, response, NKikimrBlobStorage::TEvControllerConsoleCommitResponse::SessionMismatch)) {
Expand All @@ -125,7 +125,7 @@ void TConfigsManager::Handle(TEvBlobStorage::TEvControllerConsoleCommitRequest::
CommitActor = Register(actor);
}

void TConfigsManager::Handle(TEvBlobStorage::TEvControllerValidateConfigRequest::TPtr &ev, const TActorContext &ctx) {
void TConfigsManager::Handle(TEvBlobStorage::TEvControllerValidateConfigRequest::TPtr& ev, const TActorContext& /* ctx */) {
auto response = std::make_unique<TEvBlobStorage::TEvControllerValidateConfigResponse>();
auto requestRecord = ev->Get()->Record;
response->Record.SetSkipBSCValidation(requestRecord.GetSkipBSCValidation());
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -236,7 +236,7 @@ class TTopicFilters : public ITopicFilters {
}

private:
void PushToFilter(const TFilterHandler& filterHandler, const TVector<ui64>& offsets, const TVector<ui64>& columnIndex, const TVector<const TVector<NYql::NUdf::TUnboxedValue>*>& values, ui64 numberRows) {
void PushToFilter(const TFilterHandler& filterHandler, const TVector<ui64>& /* offsets */, const TVector<ui64>& columnIndex, const TVector<const TVector<NYql::NUdf::TUnboxedValue>*>& values, ui64 numberRows) {
const auto consumer = filterHandler.GetConsumer();
const auto& columnIds = consumer->GetColumnIds();

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -204,7 +204,7 @@ class TFormatHadlerFixture : public TBaseFixture {

public:
static TCallback EmptyCheck() {
return [&](TQueue<std::pair<TRope, TVector<ui64>>>&& data) {};
return [&](TQueue<std::pair<TRope, TVector<ui64>>>&& /* data */) {};
}

static TCallback OneBatchCheck(std::function<void(TRope&& messages, TVector<ui64>&& offsets)> callback) {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -356,7 +356,7 @@ Y_UNIT_TEST_SUITE(TestPurecalcFilter) {
MakeFilter(
{{"a1", "[DataType; String]"}},
"where a2 ... 50",
[&](ui64 offset) {}
[&](ui64 /* offset */) {}
);
}
}
Expand Down Expand Up @@ -411,11 +411,11 @@ Y_UNIT_TEST_SUITE(TestFilterSet) {
CheckSuccess(MakeFilter(
{{"a1", "[DataType; String]"}},
"where a1 = \"str1\"",
[&](ui64 offset) {}
[&](ui64 /* offset */) {}
));

CheckError(
FiltersSet->AddFilter(MakeIntrusive<TFilterSetConsumer>(FilterIds.back(), TVector<ui64>(), TVector<TSchemaColumn>(), TString(), [&](ui64 offset) {}, CompileError)),
FiltersSet->AddFilter(MakeIntrusive<TFilterSetConsumer>(FilterIds.back(), TVector<ui64>(), TVector<TSchemaColumn>(), TString(), [&](ui64 /* offset */) {}, CompileError)),
EStatusId::INTERNAL_ERROR,
"Failed to create new filter, filter with id [0:0:0] already exists"
);
Expand All @@ -426,7 +426,7 @@ Y_UNIT_TEST_SUITE(TestFilterSet) {
MakeFilter(
{{"a1", "[DataType; String]"}},
"where a2 ... 50",
[&](ui64 offset) {}
[&](ui64 /* offset */) {}
);
}
}
Expand Down
2 changes: 1 addition & 1 deletion ydb/core/grpc_services/rpc_ping.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -221,7 +221,7 @@ class TExecuteTxProxyPingRPC : public TActorBootstrapped<TExecuteTxProxyPingRPC>

////////////////////////////////////////////////////////////////////////////////

void DoGrpcProxyPing(std::unique_ptr<IRequestNoOpCtx> p, const IFacilityProvider& f) {
void DoGrpcProxyPing(std::unique_ptr<IRequestNoOpCtx> p, const IFacilityProvider& /* f */) {
// we are in the GRPC proxy already (or in the check actor in case of auth check),
// thus ready to reply right here
using TRequest = TGrpcRequestNoOperationCall<Debug::GrpcProxyRequest, Debug::GrpcProxyResponse>;
Expand Down
2 changes: 1 addition & 1 deletion ydb/core/kqp/compute_actor/kqp_compute_actor_impl.h
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ class TKqpTaskRunnerExecutionContext : public TDqTaskRunnerExecutionContext {
IDqOutputConsumer::TPtr CreateOutputConsumer(const NDqProto::TTaskOutput& outputDesc,
const NMiniKQL::TType* type, NUdf::IApplyContext* applyCtx, const NMiniKQL::TTypeEnvironment& typeEnv,
const NKikimr::NMiniKQL::THolderFactory& holderFactory,
TVector<IDqOutput::TPtr>&& outputs, NUdf::IPgBuilder* pgBuilder) const override
TVector<IDqOutput::TPtr>&& outputs, NUdf::IPgBuilder* /* pgBuilder */) const override
{
return KqpBuildOutputConsumer(outputDesc, type, applyCtx, typeEnv, holderFactory, std::move(outputs), MinFillPercentage_);
}
Expand Down
2 changes: 1 addition & 1 deletion ydb/core/kqp/opt/kqp_query_plan.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -1239,7 +1239,7 @@ class TxPlanSerializer {
return AddOperator(planNode, "Aggregate", std::move(op));
}

std::variant<ui32, TArgContext> Visit(const TCoWideCombiner& combiner, TQueryPlanNode& planNode) {
std::variant<ui32, TArgContext> Visit(const TCoWideCombiner& /* combiner */, TQueryPlanNode& planNode) {
TOperator op;
op.Properties["Name"] = "Aggregate";
// op.Properties["GroupBy"] = NPlanUtils::PrettyExprStr(combiner.KeyExtractor());
Expand Down
2 changes: 1 addition & 1 deletion ydb/core/kqp/opt/logical/kqp_opt_log_indexes.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@ using namespace NYql::NNodes;

namespace {

TCoAtomList BuildKeyColumnsList(const TKikimrTableDescription& table, TPositionHandle pos, TExprContext& ctx,
TCoAtomList BuildKeyColumnsList(const TKikimrTableDescription& /* table */, TPositionHandle pos, TExprContext& ctx,
const auto& columnsToSelect) {
TVector<TExprBase> columnsList;
columnsList.reserve(columnsToSelect.size());
Expand Down
2 changes: 1 addition & 1 deletion ydb/core/kqp/opt/physical/kqp_opt_phy_sort.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -153,7 +153,7 @@ bool CompatibleSort(TOptimizerStatistics::TSortColumns& existingOrder, const TCo
TExprBase KqpBuildTopStageRemoveSort(
TExprBase node,
TExprContext& ctx,
IOptimizationContext& optCtx,
IOptimizationContext& /* optCtx */,
TTypeAnnotationContext& typeCtx,
const TParentsMap& parentsMap,
bool allowStageMultiUsage,
Expand Down
2 changes: 1 addition & 1 deletion ydb/core/kqp/ut/olap/indexes_ut.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -362,7 +362,7 @@ Y_UNIT_TEST_SUITE(KqpOlapIndexes) {
auto alterQuery =
TStringBuilder() <<
R"(ALTER OBJECT `/Root/olapStore` (TYPE TABLESTORE) SET (ACTION=UPSERT_OPTIONS, `COMPACTION_PLANNER.CLASS_NAME`=`lc-buckets`, `COMPACTION_PLANNER.FEATURES`=`
{"levels" : [{"class_name" : "Zero", "portions_live_duration" : "10s", "expected_blobs_size" : 2048000, "portions_count_available" : 1},
{"levels" : [{"class_name" : "Zero", "portions_live_duration" : "10s", "expected_blobs_size" : 2048000, "portions_count_available" : 1},
{"class_name" : "Zero"}]}`);
)";
auto session = tableClient.CreateSession().GetValueSync().GetSession();
Expand Down
8 changes: 4 additions & 4 deletions ydb/core/mind/bscontroller/console_interaction.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -46,7 +46,7 @@ namespace NKikimr::NBsController {
MakeGetBlock();
}

void TBlobStorageController::TConsoleInteraction::MakeCommitToConsole(TString& config, ui32 configVersion) {
void TBlobStorageController::TConsoleInteraction::MakeCommitToConsole(TString& /* config */, ui32 /* configVersion */) {
auto ev = MakeHolder<TEvBlobStorage::TEvControllerConsoleCommitRequest>();
ev->Record.SetYAML(Self.YamlConfig);
NTabletPipe::SendData(Self.SelfId(), ConsolePipe, ev.Release());
Expand Down Expand Up @@ -163,7 +163,7 @@ namespace NKikimr::NBsController {
Self.Send(ev->Sender, validateConfigResponse.release());
}

bool TBlobStorageController::TConsoleInteraction::ParseConfig(const TString& config, ui32& configVersion, NKikimrBlobStorage::TStorageConfig& storageConfig) {
bool TBlobStorageController::TConsoleInteraction::ParseConfig(const TString& config, ui32& /* configVersion */, NKikimrBlobStorage::TStorageConfig& storageConfig) {
NKikimrConfig::TAppConfig appConfig;
try {
appConfig = NKikimr::NYaml::Parse(config);
Expand All @@ -174,7 +174,7 @@ namespace NKikimr::NBsController {
return success;
}

TBlobStorageController::TConsoleInteraction::TCommitConfigResult::EStatus TBlobStorageController::TConsoleInteraction::CheckConfig(const TString& config, ui32& configVersion, bool skipBSCValidation,
TBlobStorageController::TConsoleInteraction::TCommitConfigResult::EStatus TBlobStorageController::TConsoleInteraction::CheckConfig(const TString& config, ui32& configVersion, bool skipBSCValidation,
NKikimrBlobStorage::TStorageConfig& storageConfig) {
if (!ParseConfig(config, configVersion, storageConfig)) {
return TConsoleInteraction::TCommitConfigResult::EStatus::ParseError;
Expand All @@ -188,7 +188,7 @@ namespace NKikimr::NBsController {
return TConsoleInteraction::TCommitConfigResult::EStatus::Success;
}

void TBlobStorageController::TConsoleInteraction::Handle(TBlobStorageController::TConsoleInteraction::TEvPrivate::TEvValidationTimeout::TPtr &ev) {
void TBlobStorageController::TConsoleInteraction::Handle(TBlobStorageController::TConsoleInteraction::TEvPrivate::TEvValidationTimeout::TPtr& /* ev */) {
if (TActivationContext::Now() < ValidationTimeout) {
return;
}
Expand Down
6 changes: 3 additions & 3 deletions ydb/core/mon/mon.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -759,7 +759,7 @@ class THttpMonServiceNodeRequest : public TActorBootstrapped<THttpMonServiceNode
CancelSubscriber = std::move(ev);
}

void Handle(NHttp::TEvHttpProxy::TEvRequestCancelled::TPtr& ev) {
void Handle(NHttp::TEvHttpProxy::TEvRequestCancelled::TPtr& /* ev */) {
if (CancelSubscriber) {
Send(CancelSubscriber->Sender, new NHttp::TEvHttpProxy::TEvRequestCancelled(), 0, CancelSubscriber->Cookie);
}
Expand Down Expand Up @@ -900,7 +900,7 @@ class THttpMonServiceMonRequest : public TActorBootstrapped<THttpMonServiceMonRe
}
}

void Disconnected(TEvInterconnect::TEvNodeDisconnected::TPtr& ev) {
void Disconnected(TEvInterconnect::TEvNodeDisconnected::TPtr& /* ev */) {
if (CurrentResponse) {
Send(Event->Sender, new NHttp::TEvHttpProxy::TEvHttpOutgoingDataChunk("NodeDisconnected"), 0, Event->Cookie);
} else {
Expand Down Expand Up @@ -1009,7 +1009,7 @@ class THttpMonInitializator : public TActorBootstrapped<THttpMonInitializator> {
Become(&THttpMonInitializator::StateWork);
}

void Handle(NHttp::TEvHttpProxy::TEvConfirmListen::TPtr& ev) {
void Handle(NHttp::TEvHttpProxy::TEvConfirmListen::TPtr& /* ev */) {
Promise.set_value();
PassAway();
}
Expand Down
6 changes: 3 additions & 3 deletions ydb/core/persqueue/partition.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -1009,7 +1009,7 @@ void TPartition::HandleOnInit(TEvPQ::TEvProposePartitionConfig::TPtr& ev, const
PendingEvents.emplace_back(ev->ReleaseBase().Release());
}

void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoRequest::TPtr& ev, const TActorContext& ctx)
void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoRequest::TPtr& ev, const TActorContext& /* ctx */)
{
PQ_LOG_D("HandleOnInit TEvPQ::TEvGetWriteInfoRequest");

Expand All @@ -1019,7 +1019,7 @@ void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoRequest::TPtr& ev, const TAc
PendingEvents.emplace_back(ev->ReleaseBase().Release());
}

void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoResponse::TPtr& ev, const TActorContext& ctx)
void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoResponse::TPtr& ev, const TActorContext& /* ctx */)
{
PQ_LOG_D("HandleOnInit TEvPQ::TEvGetWriteInfoResponse");

Expand All @@ -1028,7 +1028,7 @@ void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoResponse::TPtr& ev, const TA
PendingEvents.emplace_back(ev->ReleaseBase().Release());
}

void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoError::TPtr& ev, const TActorContext& ctx)
void TPartition::HandleOnInit(TEvPQ::TEvGetWriteInfoError::TPtr& ev, const TActorContext& /* ctx */)
{
PQ_LOG_D("HandleOnInit TEvPQ::TEvGetWriteInfoError");

Expand Down
2 changes: 1 addition & 1 deletion ydb/core/public_http/fq_handlers.h
Original file line number Diff line number Diff line change
Expand Up @@ -422,7 +422,7 @@ class TJsonStartQuery : public TGrpcCallWrapper<FederatedQuery::DescribeQueryReq
TIntrusivePtr<TGrpcRequestContextWrapper> requestContext = MakeIntrusive<TGrpcRequestContextWrapper>(
RequestContext,
std::move(describeRequest),
[query_id = std::move(queryId), actorSystem = TActivationContext::ActorSystem()](const THttpRequestContext& requestContext, const TJsonSettings& jsonSettings, NProtoBuf::Message* resp, ui32 status) {
[query_id = std::move(queryId), actorSystem = TActivationContext::ActorSystem()](const THttpRequestContext& requestContext, const TJsonSettings& jsonSettings, NProtoBuf::Message* resp, ui32 /* status */) {

Y_ABORT_UNLESS(resp);
Y_ABORT_UNLESS(resp->GetArena());
Expand Down
4 changes: 2 additions & 2 deletions ydb/core/statistics/service/ut/ut_http_request.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -39,13 +39,13 @@ void ProbeTest(bool isServerless) {
const auto sender = runtime.AllocateEdgeActor();

bool firstStatsToSA = false;
auto statsObserver1 = runtime.AddObserver<TEvStatistics::TEvSchemeShardStats>([&](auto& ev){
auto statsObserver1 = runtime.AddObserver<TEvStatistics::TEvSchemeShardStats>([&](auto& /* ev */){
firstStatsToSA = true;
});
runtime.WaitFor("TEvSchemeShardStats 1", [&]{ return firstStatsToSA; });

bool secondStatsToSA = false;
auto statsObserver2 = runtime.AddObserver<TEvStatistics::TEvSchemeShardStats>([&](auto& ev){
auto statsObserver2 = runtime.AddObserver<TEvStatistics::TEvSchemeShardStats>([&](auto& /* ev */){
secondStatsToSA = true;
});
runtime.WaitFor("TEvSchemeShardStats 2", [&]{ return secondStatsToSA; });
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -135,14 +135,14 @@ void TTxBlobsWritingFinished::DoComplete(const TActorContext& ctx) {
Self->SetupCompaction(pathIds);
}

TTxBlobsWritingFinished::TTxBlobsWritingFinished(TColumnShard* self, const NKikimrProto::EReplyStatus writeStatus,
TTxBlobsWritingFinished::TTxBlobsWritingFinished(TColumnShard* self, const NKikimrProto::EReplyStatus /* writeStatus */,
const std::shared_ptr<NOlap::IBlobsWritingAction>& writingActions, TInsertedPortions&& pack)
: TBase(self, "TTxBlobsWritingFinished")
, Pack(std::move(pack))
, WritingActions(writingActions) {
}

bool TTxBlobsWritingFailed::DoExecute(TTransactionContext& txc, const TActorContext& ctx) {
bool TTxBlobsWritingFailed::DoExecute(TTransactionContext& txc, const TActorContext& /* ctx */) {
for (auto&& wResult : Pack.GetWriteResults()) {
const auto& writeMeta = wResult.GetWriteMeta();
AFL_VERIFY(!writeMeta.HasLongTxId());
Expand Down
2 changes: 1 addition & 1 deletion ydb/core/tx/columnshard/columnshard__write.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -64,7 +64,7 @@ TColumnShard::EOverloadStatus TColumnShard::CheckOverloadedWait(const ui64 pathI
return EOverloadStatus::None;
}

TColumnShard::EOverloadStatus TColumnShard::CheckOverloadedImmediate(const ui64 pathId) const {
TColumnShard::EOverloadStatus TColumnShard::CheckOverloadedImmediate(const ui64 /* pathId */) const {
if (IsAnyChannelYellowStop()) {
return EOverloadStatus::Disk;
}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@ std::shared_ptr<NDataLocks::ILock> TMovePortionsChange::DoBuildDataLock(const TS
}

void TMovePortionsChange::DoApplyOnExecute(
NColumnShard::TColumnShard* self, TWriteIndexContext& context, const TDataAccessorsResult& fetchedDataAccessor) {
NColumnShard::TColumnShard* /* self */, TWriteIndexContext& context, const TDataAccessorsResult& fetchedDataAccessor) {
auto schemaPtr = context.EngineLogs.GetVersionedIndex().GetLastSchema();
for (auto&& [_, i] : Portions) {
const auto pred = [&](TPortionInfo& portionCopy) {
Expand All @@ -28,7 +28,7 @@ void TMovePortionsChange::DoApplyOnExecute(
}

void TMovePortionsChange::DoApplyOnComplete(
NColumnShard::TColumnShard* self, TWriteIndexCompleteContext& context, const TDataAccessorsResult& /*fetchedDataAccessor*/) {
NColumnShard::TColumnShard* /* self */, TWriteIndexCompleteContext& context, const TDataAccessorsResult& /*fetchedDataAccessor*/) {
if (!Portions.size()) {
return;
}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@ std::shared_ptr<NDataLocks::ILock> TRemovePortionsChange::DoBuildDataLock(
}

void TRemovePortionsChange::DoApplyOnExecute(
NColumnShard::TColumnShard* self, TWriteIndexContext& context, const TDataAccessorsResult& fetchedDataAccessors) {
NColumnShard::TColumnShard* /* self */, TWriteIndexContext& context, const TDataAccessorsResult& fetchedDataAccessors) {
THashSet<ui64> usedPortionIds;
auto schemaPtr = context.EngineLogs.GetVersionedIndex().GetLastSchema();
for (auto&& [_, i] : Portions) {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -12,7 +12,7 @@ namespace NKikimr::NOlap::NCompaction {

std::shared_ptr<NArrow::TColumnFilter> TGeneralCompactColumnEngineChanges::BuildPortionFilter(
const std::optional<NKikimr::NOlap::TGranuleShardingInfo>& shardingActual, const std::shared_ptr<NArrow::TGeneralContainer>& batch,
const TPortionInfo& pInfo, const THashSet<ui64>& portionsInUsage, const ISnapshotSchema::TPtr& resultSchema) const {
const TPortionInfo& pInfo, const THashSet<ui64>& portionsInUsage, const ISnapshotSchema::TPtr& /* resultSchema */) const {
std::shared_ptr<NArrow::TColumnFilter> filter;
if (shardingActual && pInfo.NeedShardingFilter(*shardingActual)) {
std::set<std::string> fieldNames;
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -12,7 +12,7 @@ std::unique_ptr<TScanIteratorBase> TReadMetadata::StartScan(const std::shared_pt
}

TConclusionStatus TReadMetadata::DoInitCustom(
const NColumnShard::TColumnShard* owner, const TReadDescription& readDescription, const TDataStorageAccessor& dataAccessor) {
const NColumnShard::TColumnShard* /* owner */, const TReadDescription& /* readDescription */, const TDataStorageAccessor& /* dataAccessor */) {
return TConclusionStatus::Success();
}

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@ class TPortionsIndex {
const TGranuleMeta& Owner;

public:
TPortionsIndex(const TGranuleMeta& owner, const NColumnShard::TPortionsIndexCounters& counters)
TPortionsIndex(const TGranuleMeta& owner, const NColumnShard::TPortionsIndexCounters& /* counters */)
: Owner(owner)
{
Y_UNUSED(Owner);
Expand Down
4 changes: 2 additions & 2 deletions ydb/core/tx/columnshard/hooks/testing/controller.h
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,7 @@ class TController: public TReadOnlyController {
YDB_ACCESSOR(std::optional<ui64>, OverrideMemoryLimitForPortionReading, 100);
YDB_ACCESSOR(std::optional<ui64>, OverrideLimitForPortionsMetadataAsk, 1);
YDB_ACCESSOR(std::optional<NOlap::NSplitter::TSplitSettings>, OverrideBlobSplitSettings, NOlap::NSplitter::TSplitSettings::BuildForTests());

YDB_ACCESSOR_DEF(std::optional<NKikimrProto::EReplyStatus>, OverrideBlobPutResultOnWriteValue);

EOptimizerCompactionWeightControl CompactionControl = EOptimizerCompactionWeightControl::Force;
Expand Down Expand Up @@ -201,7 +201,7 @@ class TController: public TReadOnlyController {
virtual TDuration DoGetMaxReadStaleness(const TDuration def) const override {
return OverrideMaxReadStaleness.value_or(def);
}
virtual ui64 DoGetMetadataRequestSoftMemoryLimit(const ui64 def) const override {
virtual ui64 DoGetMetadataRequestSoftMemoryLimit(const ui64 /* def */) const override {
return 0;
}
virtual EOptimizerCompactionWeightControl GetCompactionControl() const override {
Expand Down
Loading

0 comments on commit 6f59478

Please sign in to comment.