Skip to content

Commit d0b8371

Browse files
r-barnesfacebook-github-bot
authored andcommitted
fix: unused-variable issues in velox
Differential Revision: D67076456
1 parent 59d4741 commit d0b8371

Some content is hidden

Large Commits have some content hidden by default. Use the searchbox below for content that may be hidden.

56 files changed

+15
-131
lines changed

velox/common/base/tests/IndexedPriorityQueueTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -232,7 +232,6 @@ TEST_F(IndexedPriorityQueueTest, remove) {
232232
}
233233

234234
TEST_F(IndexedPriorityQueueTest, fuzz) {
235-
const int numIterations{1000};
236235
std::mt19937 rng{100};
237236
IndexedPriorityQueue<uint32_t, true> maxQueue;
238237
fuzz<uint32_t, true>(maxQueue, 1'000, rng);

velox/common/base/tests/ScratchTest.cpp

+1-1
Original file line numberDiff line numberDiff line change
@@ -35,7 +35,7 @@ TEST(ScratchTest, basic) {
3535
{
3636
ScratchPtr<int32_t> ints(scratch);
3737
ScratchPtr<int64_t> longs(scratch);
38-
auto tempLongs = longs.get(2000);
38+
longs.get(2000);
3939
auto tempInts = ints.get(1000);
4040
std::fill(tempInts, tempInts + 1000, -1);
4141
std::fill(tempInts, tempInts + 2000, -1);

velox/common/base/tests/SimdUtilTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -171,7 +171,6 @@ TEST_F(SimdUtilTest, gather32) {
171171

172172
TEST_F(SimdUtilTest, gather64) {
173173
int32_t indices4[4] = {3, 2, 1, 0};
174-
int32_t indices3[4] = {3, 2, 1, 1 << 31};
175174
int64_t data[4] = {44, 55, 66, 77};
176175
constexpr int kBatchSize = xsimd::batch<int64_t>::size;
177176
const int32_t* indices = indices4 + (4 - kBatchSize);

velox/common/memory/tests/AllocationPoolTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -53,7 +53,6 @@ TEST_F(AllocationPoolTest, hugePages) {
5353
allocationPool->setHugePageThreshold(128 << 10);
5454
int32_t counter = 0;
5555
for (;;) {
56-
int32_t usedKB = 0;
5756
allocationPool->newRun(32 << 10);
5857
// Initial allocations round up to 64K
5958
EXPECT_EQ(1, allocationPool->numRanges());

velox/common/memory/tests/ArbitrationParticipantTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -1372,7 +1372,6 @@ DEBUG_ONLY_TEST_F(ArbitrationParticipantTest, reclaimLock) {
13721372
auto task = createTask(kMemoryCapacity);
13731373
const auto config = arbitrationConfig();
13741374
auto participant = ArbitrationParticipant::create(10, task->pool(), &config);
1375-
const uint64_t allocatedBytes = 32 * MB;
13761375
for (int i = 0; i < 32; ++i) {
13771376
task->allocate(MB);
13781377
}

velox/common/memory/tests/MemoryAllocatorTest.cpp

-4
Original file line numberDiff line numberDiff line change
@@ -637,7 +637,6 @@ TEST_P(MemoryAllocatorTest, allocationClass2) {
637637

638638
TEST_P(MemoryAllocatorTest, stats) {
639639
const std::vector<MachinePageCount>& sizes = instance_->sizeClasses();
640-
MachinePageCount capacity = kCapacityPages;
641640
for (auto i = 0; i < sizes.size(); ++i) {
642641
std::unique_ptr<Allocation> allocation = std::make_unique<Allocation>();
643642
auto size = sizes[i];
@@ -963,7 +962,6 @@ TEST_P(MemoryAllocatorTest, allocContiguous) {
963962
for (const auto& testData : testSettings) {
964963
SCOPED_TRACE(fmt::format("{} useMmap{}", testData.debugString(), useMmap_));
965964
setupAllocator();
966-
const MachinePageCount nonContiguousPages = 100;
967965
Allocation allocation;
968966
if (testData.nonContiguousPages != 0) {
969967
instance_->allocateNonContiguous(testData.nonContiguousPages, allocation);
@@ -1065,7 +1063,6 @@ TEST_P(MemoryAllocatorTest, allocContiguousFail) {
10651063
SCOPED_TRACE(
10661064
fmt::format("{} useMmap {}", testData.debugString(), useMmap_));
10671065
setupAllocator();
1068-
const MachinePageCount nonContiguousPages = 100;
10691066
Allocation allocation;
10701067
if (testData.nonContiguousPages != 0) {
10711068
instance_->allocateNonContiguous(testData.nonContiguousPages, allocation);
@@ -1376,7 +1373,6 @@ TEST_P(MemoryAllocatorTest, StlMemoryAllocator) {
13761373
// Allocation from classes and ContiguousAllocation outside size
13771374
// classes.
13781375
constexpr int32_t kNumDoubles = 256 * 1024;
1379-
size_t capacity = 0;
13801376
for (auto i = 0; i < kNumDoubles; i++) {
13811377
data.push_back(i);
13821378
}

velox/common/memory/tests/MemoryManagerTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -554,7 +554,6 @@ TEST_F(MemoryManagerTest, concurrentPoolAccess) {
554554
std::atomic<bool> stopCheck{false};
555555
std::thread checkThread([&]() {
556556
while (!stopCheck) {
557-
const int numPools = manager.numPools();
558557
std::this_thread::sleep_for(std::chrono::microseconds(1));
559558
}
560559
});

velox/common/memory/tests/MemoryPoolTest.cpp

-10
Original file line numberDiff line numberDiff line change
@@ -144,7 +144,6 @@ class MemoryPoolTest : public testing::TestWithParam<TestParam> {
144144
};
145145

146146
TEST_P(MemoryPoolTest, ctor) {
147-
constexpr uint16_t kAlignment = 64;
148147
setupMemory({.alignment = 64, .allocatorCapacity = kDefaultCapacity});
149148
MemoryManager& manager = *getMemoryManager();
150149
const int64_t capacity = 4 * GB;
@@ -690,7 +689,6 @@ TEST_P(MemoryPoolTest, alignmentCheck) {
690689
ASSERT_EQ(
691690
pool->alignment(),
692691
alignment == 0 ? MemoryAllocator::kMinAlignment : alignment);
693-
const int32_t kTestIterations = 10;
694692
for (int32_t i = 0; i < 10; ++i) {
695693
const int64_t bytesToAlloc = 1 + folly::Random::rand32() % (1 * MB);
696694
void* ptr = pool->allocate(bytesToAlloc);
@@ -1028,11 +1026,6 @@ TEST_P(MemoryPoolTest, contiguousAllocate) {
10281026
ASSERT_GE(numAllocatedPages, 0);
10291027
allocations.erase(allocations.begin() + freeAllocationIdx);
10301028
}
1031-
const MachinePageCount minSizeClass = folly::Random().oneIn(4)
1032-
? 0
1033-
: std::min(
1034-
manager->allocator()->largestSizeClass(),
1035-
folly::Random().rand32() % kMaxAllocationPages);
10361029
pool->allocateContiguous(pagesToAllocate, allocation);
10371030
numAllocatedPages += allocation.numPages();
10381031
for (int32_t j = 0; j < allocation.size(); ++j) {
@@ -1082,7 +1075,6 @@ TEST_P(MemoryPoolTest, contiguousAllocateExceedLimit) {
10821075
TEST_P(MemoryPoolTest, badContiguousAllocation) {
10831076
auto manager = getMemoryManager();
10841077
auto pool = manager->addLeafPool("badContiguousAllocation");
1085-
constexpr MachinePageCount kAllocSize = 8;
10861078
ContiguousAllocation allocation;
10871079
ASSERT_THROW(pool->allocateContiguous(0, allocation), VeloxRuntimeError);
10881080
}
@@ -2500,7 +2492,6 @@ TEST_P(MemoryPoolTest, concurrentUpdateToSharedPools) {
25002492
TEST_P(MemoryPoolTest, concurrentPoolStructureAccess) {
25012493
folly::Random::DefaultGenerator rng;
25022494
rng.seed(1234);
2503-
constexpr int64_t kMaxMemory = 8 * GB;
25042495
MemoryManager& manager = *getMemoryManager();
25052496
auto root = manager.addRootPool();
25062497
std::atomic<int64_t> poolId{0};
@@ -2665,7 +2656,6 @@ TEST(MemoryPoolTest, debugMode) {
26652656

26662657
TEST(MemoryPoolTest, debugModeWithFilter) {
26672658
constexpr int64_t kMaxMemory = 10 * GB;
2668-
constexpr int64_t kNumIterations = 100;
26692659
const std::vector<int64_t> kAllocSizes = {128, 8 * KB, 2 * MB};
26702660
const std::vector<bool> debugEnabledSet{true, false};
26712661
for (const auto& debugEnabled : debugEnabledSet) {

velox/connectors/hive/tests/HiveDataSinkTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -976,7 +976,6 @@ DEBUG_ONLY_TEST_F(HiveDataSinkTest, sortWriterAbortDuringFinish) {
976976
dataSink->appendData(vector);
977977
}
978978

979-
std::atomic_int injectCount{0};
980979
SCOPED_TESTVALUE_SET(
981980
"facebook::velox::dwrf::Writer::write",
982981
std::function<void(dwrf::Writer*)>([&](dwrf::Writer* /*unused*/) {

velox/dwio/common/tests/BitPackDecoderBenchmark.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -542,7 +542,6 @@ void naiveDecodeBitsLE(
542542
}
543543
return;
544544
}
545-
auto lastSafe = bufferEnd - sizeof(uint64_t);
546545
int32_t numSafeRows = numRows;
547546
bool anyUnsafe = false;
548547
if (bufferEnd) {

velox/dwio/common/tests/IntDecoderBenchmark.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -910,7 +910,6 @@ BENCHMARK_RELATIVE(decodeNew_16) {
910910
BENCHMARK(decodeOld_32) {
911911
size_t currentLen = len_u32;
912912
const size_t startingLen = len_u32;
913-
int32_t i = 0;
914913
while (currentLen != 0) {
915914
auto result =
916915
readVuLong(buffer_u32.data() + (startingLen - currentLen), currentLen);

velox/dwio/common/tests/utils/DataSetBuilder.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -254,7 +254,6 @@ DataSetBuilder& DataSetBuilder::makeMapStringValues(
254254
auto keyKind = map->type()->childAt(0)->kind();
255255
auto valueKind = map->type()->childAt(1)->kind();
256256
auto offsets = map->rawOffsets();
257-
auto sizes = map->rawSizes();
258257
int32_t offsetIndex = 0;
259258
auto mapSize = map->size();
260259
auto getNextOffset = [&]() {

velox/dwio/dwrf/test/CacheInputTest.cpp

-2
Original file line numberDiff line numberDiff line change
@@ -476,8 +476,6 @@ TEST_F(CacheTest, window) {
476476
auto cacheInput = dynamic_cast<CacheInputStream*>(stream.get());
477477
EXPECT_TRUE(cacheInput != nullptr);
478478
ASSERT_EQ(cacheInput->getName(), "CacheInputStream 0 of 13631488");
479-
auto maxSize =
480-
allocator_->sizeClasses().back() * memory::AllocationTraits::kPageSize;
481479
const void* buffer;
482480
int32_t size;
483481
int32_t numRead = 0;

velox/dwio/dwrf/test/ColumnWriterTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -1873,7 +1873,6 @@ int64_t generateRangeWithCustomLimits(
18731873
// Generate the range such that we have similar amounts of values generated
18741874
// for each exponent.
18751875
double center = size % 2 ? -0.5 : interval / 2 - 0.5;
1876-
double value = center + (i - size / 2) * interval;
18771876
// Return a guard-railed value with the numeric limits.
18781877
// NOTE: There can be a more compact way to write this if we cast i and size
18791878
// to signed types, but it's not worth the effort enforcing the assumptions.

velox/dwio/dwrf/test/DecryptionTests.cpp

+1-1
Original file line numberDiff line numberDiff line change
@@ -43,7 +43,7 @@ TEST(Decryption, NoKeyProvider) {
4343
auto type = parser.parse("struct<a:int>");
4444
proto::Footer footer;
4545
ProtoUtils::writeType(*type, footer);
46-
auto enc = footer.mutable_encryption();
46+
footer.mutable_encryption();
4747
TestDecrypterFactory factory;
4848
ASSERT_THROW(
4949
DecryptionHandler::create(footer, &factory), exception::LoggedException);

velox/dwio/dwrf/test/E2EReaderTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -231,7 +231,6 @@ TEST_P(E2EReaderTest, SharedDictionaryFlatmapReadAsStruct) {
231231
ASSERT_TRUE(resultTypeRow.childAt(col)->isMap());
232232
ASSERT_EQ(batchRow->childAt(col)->typeKind(), TypeKind::MAP);
233233
auto& resultTypeChild = resultTypeRow.childAt(col)->as<TypeKind::MAP>();
234-
auto* batchRowChild = batchRow->childAt(col)->as<MapVector>();
235234
ASSERT_EQ(
236235
resultTypeChild.keyType()->kind(), schemaChild.keyType()->kind());
237236
ASSERT_EQ(

velox/dwio/dwrf/test/E2EWriterTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -1960,7 +1960,6 @@ TEST_F(E2EWriterTest, memoryReclaimAfterClose) {
19601960
VELOX_ASSERT_THROW(writer->flush(), "Writer is not running");
19611961

19621962
memory::MemoryReclaimer::Stats stats;
1963-
const auto oldCapacity = writerPool->capacity();
19641963
writerPool->reclaim(1L << 30, 0, stats);
19651964
if (testData.abort || !testData.canReclaim) {
19661965
ASSERT_EQ(stats.numNonReclaimableAttempts, 0);

velox/dwio/parquet/reader/IntegerColumnReader.h

-1
Original file line numberDiff line numberDiff line change
@@ -68,7 +68,6 @@ class IntegerColumnReader : public dwio::common::SelectiveIntegerColumnReader {
6868
int64_t offset,
6969
const RowSet& rows,
7070
const uint64_t* /*incomingNulls*/) override {
71-
auto& data = formatData_->as<ParquetData>();
7271
VELOX_WIDTH_DISPATCH(
7372
parquetSizeOfIntKind(fileType_->type()->kind()),
7473
prepareRead,

velox/dwio/parquet/reader/TimestampColumnReader.h

-1
Original file line numberDiff line numberDiff line change
@@ -119,7 +119,6 @@ class TimestampColumnReader : public IntegerColumnReader {
119119
int64_t offset,
120120
const RowSet& rows,
121121
const uint64_t* /*incomingNulls*/) override {
122-
auto& data = formatData_->as<ParquetData>();
123122
// Use int128_t as a workaround. Timestamp in Velox is of 16-byte length.
124123
prepareRead<int128_t>(offset, rows, nullptr);
125124
readCommon<TimestampColumnReader, true>(rows);

velox/dwio/parquet/tests/reader/ParquetReaderTest.cpp

-4
Original file line numberDiff line numberDiff line change
@@ -1365,7 +1365,6 @@ TEST_F(ParquetReaderTest, arrayOfMapOfIntKeyArrayValue) {
13651365
facebook::velox::dwio::common::ReaderOptions readerOptions{leafPool_.get()};
13661366
auto reader = createReader(sample, readerOptions);
13671367
EXPECT_EQ(reader->rowType()->toString(), expectedVeloxType);
1368-
auto numRows = reader->numberOfRows();
13691368
auto type = reader->typeWithId();
13701369
RowReaderOptions rowReaderOpts;
13711370
auto rowType = ROW({"test"}, {ARRAY(MAP(VARCHAR(), ARRAY(INTEGER())))});
@@ -1399,7 +1398,6 @@ TEST_F(ParquetReaderTest, arrayOfMapOfIntKeyStructValue) {
13991398
facebook::velox::dwio::common::ReaderOptions readerOptions{leafPool_.get()};
14001399
auto reader = createReader(sample, readerOptions);
14011400
EXPECT_EQ(reader->rowType()->toString(), expectedVeloxType);
1402-
auto numRows = reader->numberOfRows();
14031401
auto type = reader->typeWithId();
14041402
RowReaderOptions rowReaderOpts;
14051403
auto rowType = reader->rowType();
@@ -1433,7 +1431,6 @@ TEST_F(ParquetReaderTest, struct_of_array_of_array) {
14331431
getExampleFilePath("struct_of_array_of_array.parquet"));
14341432
facebook::velox::dwio::common::ReaderOptions readerOptions{leafPool_.get()};
14351433
auto reader = createReader(sample, readerOptions);
1436-
auto numRows = reader->numberOfRows();
14371434
auto type = reader->typeWithId();
14381435
EXPECT_EQ(type->size(), 1ULL);
14391436
EXPECT_EQ(reader->rowType()->toString(), expectedVeloxType);
@@ -1507,7 +1504,6 @@ TEST_F(ParquetReaderTest, testLzoDataPage) {
15071504
rowReaderOpts.setScanSpec(makeScanSpec(outputRowType));
15081505
auto rowReader = reader->createRowReader(rowReaderOpts);
15091506

1510-
uint64_t total = 0;
15111507
VectorPtr result = BaseVector::create(outputRowType, 0, &*leafPool_);
15121508
rowReader->next(23'547ULL, result);
15131509
EXPECT_EQ(23'547ULL, result->size());

velox/exec/HashJoinBridge.cpp

+1-1
Original file line numberDiff line numberDiff line change
@@ -256,7 +256,7 @@ void HashJoinBridge::appendSpilledHashTablePartitionsLocked(
256256
}
257257
auto spillPartitionIdSet = toSpillPartitionIdSet(spillPartitionSet);
258258
if (restoringSpillPartitionId_.has_value()) {
259-
for (const auto& id : spillPartitionIdSet) {
259+
for ([[maybe_unused]] const auto& id : spillPartitionIdSet) {
260260
VELOX_DCHECK_LT(
261261
restoringSpillPartitionId_->partitionBitOffset(),
262262
id.partitionBitOffset());

velox/exec/fuzzer/DuckQueryRunner.cpp

-12
Original file line numberDiff line numberDiff line change
@@ -423,18 +423,6 @@ std::optional<std::string> DuckQueryRunner::toSql(
423423

424424
std::optional<std::string> DuckQueryRunner::toSql(
425425
const std::shared_ptr<const core::NestedLoopJoinNode>& joinNode) {
426-
const auto& joinKeysToSql = [](auto keys) {
427-
std::stringstream out;
428-
for (auto i = 0; i < keys.size(); ++i) {
429-
if (i > 0) {
430-
out << ", ";
431-
}
432-
out << keys[i]->name();
433-
}
434-
return out.str();
435-
};
436-
437-
const auto& outputNames = joinNode->outputType()->names();
438426
std::stringstream sql;
439427

440428
// Nested loop join without filter.

velox/exec/fuzzer/PrestoQueryRunner.cpp

-12
Original file line numberDiff line numberDiff line change
@@ -638,18 +638,6 @@ std::optional<std::string> PrestoQueryRunner::toSql(
638638

639639
std::optional<std::string> PrestoQueryRunner::toSql(
640640
const std::shared_ptr<const core::NestedLoopJoinNode>& joinNode) {
641-
const auto& joinKeysToSql = [](auto keys) {
642-
std::stringstream out;
643-
for (auto i = 0; i < keys.size(); ++i) {
644-
if (i > 0) {
645-
out << ", ";
646-
}
647-
out << keys[i]->name();
648-
}
649-
return out.str();
650-
};
651-
652-
const auto& outputNames = joinNode->outputType()->names();
653641
std::stringstream sql;
654642

655643
// Nested loop join without filter.

velox/exec/tests/AggregationTest.cpp

-2
Original file line numberDiff line numberDiff line change
@@ -1049,7 +1049,6 @@ TEST_F(AggregationTest, largeValueRangeArray) {
10491049

10501050
TEST_F(AggregationTest, partialAggregationMemoryLimitIncrease) {
10511051
constexpr int64_t kGB = 1 << 30;
1052-
constexpr int64_t kB = 1 << 10;
10531052
auto vectors = {
10541053
makeRowVector({makeFlatVector<int32_t>(
10551054
100, [](auto row) { return row; }, nullEvery(5))}),
@@ -1141,7 +1140,6 @@ TEST_F(AggregationTest, partialAggregationMaybeReservationReleaseCheck) {
11411140

11421141
constexpr int64_t kGB = 1 << 30;
11431142
const int64_t kMaxPartialMemoryUsage = 1 * kGB;
1144-
const int64_t kMaxUserMemoryUsage = 2 * kMaxPartialMemoryUsage;
11451143
// Make sure partial aggregation runs out of memory after first batch.
11461144
CursorParameters params;
11471145
params.queryCtx = core::QueryCtx::create(executor_.get());

velox/exec/tests/HashJoinTest.cpp

-2
Original file line numberDiff line numberDiff line change
@@ -6861,7 +6861,6 @@ TEST_F(HashJoinTest, leftJoinPreserveProbeOrder) {
68616861
}
68626862

68636863
DEBUG_ONLY_TEST_F(HashJoinTest, minSpillableMemoryReservation) {
6864-
constexpr int64_t kMaxBytes = 1LL << 30; // 1GB
68656864
VectorFuzzer fuzzer({.vectorSize = 1000}, pool());
68666865
const int32_t numBuildVectors = 10;
68676866
std::vector<RowVectorPtr> buildVectors;
@@ -7411,7 +7410,6 @@ DEBUG_ONLY_TEST_F(HashJoinTest, exceptionDuringFinishJoinBuild) {
74117410

74127411
DEBUG_ONLY_TEST_F(HashJoinTest, arbitrationTriggeredDuringParallelJoinBuild) {
74137412
std::unique_ptr<memory::MemoryManager> memoryManager = createMemoryManager();
7414-
const auto& arbitrator = memoryManager->arbitrator();
74157413
const uint64_t numDrivers = 2;
74167414

74177415
// Large build side key product to bump hash mode to kHash instead of kArray

velox/exec/tests/OutputBufferManagerTest.cpp

-1
Original file line numberDiff line numberDiff line change
@@ -329,7 +329,6 @@ class OutputBufferManagerTest : public testing::Test {
329329
return;
330330
}
331331
const int64_t maxBytes = folly::Random().oneIn(4, rng) ? 32'000'000 : 1;
332-
int64_t receivedSequence;
333332
bool atEnd{false};
334333
folly::EventCount dataWait;
335334
auto dataWaitKey = dataWait.prepareWait();

velox/exec/tests/PrefixSortTest.cpp

-2
Original file line numberDiff line numberDiff line change
@@ -151,7 +151,6 @@ const RowVectorPtr PrefixSortTest::generateExpectedResult(
151151
}
152152

153153
TEST_F(PrefixSortTest, singleKey) {
154-
const int numRows = 5;
155154
const int columnsSize = 7;
156155

157156
// Vectors without nulls.
@@ -183,7 +182,6 @@ TEST_F(PrefixSortTest, singleKey) {
183182
}
184183

185184
TEST_F(PrefixSortTest, singleKeyWithNulls) {
186-
const int numRows = 5;
187185
const int columnsSize = 7;
188186

189187
Timestamp ts = {5, 5};

velox/exec/tests/RowContainerTest.cpp

+1-1
Original file line numberDiff line numberDiff line change
@@ -2476,7 +2476,7 @@ TEST_F(RowContainerTest, invalidatedColumnStats) {
24762476
EXPECT_EQ(data->columnStats(4)->numCells(), 0);
24772477

24782478
for (int i = 0; i < kNumRows; ++i) {
2479-
auto row = data->newRow();
2479+
data->newRow();
24802480
}
24812481
EXPECT_EQ(kNumRows, data->numRows());
24822482
RowContainerIterator iter;

velox/exec/tests/ScaleWriterLocalPartitionTest.cpp

-2
Original file line numberDiff line numberDiff line change
@@ -690,7 +690,6 @@ TEST_F(ScaleWriterLocalPartitionTest, unpartitionBasic) {
690690
TEST_F(ScaleWriterLocalPartitionTest, unpartitionFuzzer) {
691691
const std::vector<RowVectorPtr> inputVectors = makeVectors(256, 512);
692692
const uint64_t queryCapacity = 256 << 20;
693-
const uint32_t maxDrivers = 32;
694693
const uint32_t maxExchanegBufferSize = 2 << 20;
695694

696695
for (bool fastConsumer : {false, true}) {
@@ -914,7 +913,6 @@ TEST_F(ScaleWriterLocalPartitionTest, partitionFuzzer) {
914913
const std::vector<RowVectorPtr> inputVectors =
915914
makeVectors(1024, 256, {1, 2, 3, 4, 5, 6, 7, 8});
916915
const uint64_t queryCapacity = 256 << 20;
917-
const uint32_t maxDrivers = 32;
918916
const uint32_t maxExchanegBufferSize = 2 << 20;
919917

920918
for (bool fastConsumer : {false, true}) {

velox/exec/tests/SortBufferTest.cpp

-2
Original file line numberDiff line numberDiff line change
@@ -598,7 +598,6 @@ DEBUG_ONLY_TEST_P(SortBufferTest, spillDuringInput) {
598598
const std::shared_ptr<memory::MemoryPool> fuzzerPool =
599599
memory::memoryManager()->addLeafPool("spillDuringInput");
600600
VectorFuzzer fuzzer({.vectorSize = 1024}, fuzzerPool.get());
601-
uint64_t totalNumInput{0};
602601

603602
ASSERT_EQ(memory::spillMemoryPool()->stats().usedBytes, 0);
604603
const auto peakSpillMemoryUsage =
@@ -650,7 +649,6 @@ DEBUG_ONLY_TEST_P(SortBufferTest, spillDuringOutput) {
650649
const std::shared_ptr<memory::MemoryPool> fuzzerPool =
651650
memory::memoryManager()->addLeafPool("spillDuringOutput");
652651
VectorFuzzer fuzzer({.vectorSize = 1024}, fuzzerPool.get());
653-
uint64_t totalNumInput{0};
654652

655653
ASSERT_EQ(memory::spillMemoryPool()->stats().usedBytes, 0);
656654
const auto peakSpillMemoryUsage =

0 commit comments

Comments
 (0)