Skip to content

Commit

Permalink
Merge pull request #53180 from ClickHouse/ditch-tons-of-garbage
Browse files Browse the repository at this point in the history
Ditch tons of garbage
  • Loading branch information
alexey-milovidov committed Aug 10, 2023
2 parents be55bbf + 2592382 commit bb57caa
Show file tree
Hide file tree
Showing 80 changed files with 30 additions and 102 deletions.
2 changes: 0 additions & 2 deletions base/base/JSON.cpp
Expand Up @@ -7,8 +7,6 @@
#include <base/find_symbols.h>
#include <base/preciseExp10.h>

#include <iostream>

#define JSON_MAX_DEPTH 100


Expand Down
2 changes: 1 addition & 1 deletion base/base/wide_integer_impl.h
Expand Up @@ -12,7 +12,6 @@
#include <tuple>
#include <limits>

#include <boost/multiprecision/cpp_bin_float.hpp>
#include <boost/math/special_functions/fpclassify.hpp>

// NOLINTBEGIN(*)
Expand All @@ -22,6 +21,7 @@
#define CONSTEXPR_FROM_DOUBLE constexpr
using FromDoubleIntermediateType = long double;
#else
#include <boost/multiprecision/cpp_bin_float.hpp>
/// `wide_integer_from_builtin` can't be constexpr with non-literal `cpp_bin_float_double_extended`
#define CONSTEXPR_FROM_DOUBLE
using FromDoubleIntermediateType = boost::multiprecision::cpp_bin_float_double_extended;
Expand Down
1 change: 0 additions & 1 deletion base/poco/Data/ODBC/src/Unicode_UNIXODBC.cpp
Expand Up @@ -19,7 +19,6 @@
#include "Poco/UTF16Encoding.h"
#include "Poco/Buffer.h"
#include "Poco/Exception.h"
#include <iostream>


using Poco::Buffer;
Expand Down
1 change: 0 additions & 1 deletion base/poco/Foundation/src/Task.cpp
Expand Up @@ -16,7 +16,6 @@
#include "Poco/TaskManager.h"
#include "Poco/Exception.h"

#include <iostream>
#include <array>


Expand Down
1 change: 0 additions & 1 deletion base/poco/JSON/src/Object.cpp
Expand Up @@ -14,7 +14,6 @@

#include "Poco/JSON/Object.h"
#include <iostream>
#include <sstream>


using Poco::Dynamic::Var;
Expand Down
1 change: 0 additions & 1 deletion base/poco/Net/src/HTTPClientSession.cpp
Expand Up @@ -26,7 +26,6 @@
#include "Poco/CountingStream.h"
#include "Poco/RegularExpression.h"
#include <sstream>
#include <iostream>


using Poco::NumberFormatter;
Expand Down
2 changes: 2 additions & 0 deletions programs/disks/ICommand.cpp
@@ -1,4 +1,6 @@
#include "ICommand.h"
#include <iostream>


namespace DB
{
Expand Down
1 change: 1 addition & 0 deletions src/Access/MemoryAccessStorage.h
Expand Up @@ -6,6 +6,7 @@
#include <memory>
#include <mutex>
#include <unordered_map>
#include <boost/container/flat_set.hpp>


namespace DB
Expand Down
1 change: 0 additions & 1 deletion src/AggregateFunctions/tests/gtest_ranks.cpp
Expand Up @@ -2,7 +2,6 @@
#include <IO/ReadBufferFromString.h>
#include <Common/PODArray.h>
#include <AggregateFunctions/StatCommon.h>
#include <iostream>

#include <gtest/gtest.h>

Expand Down
3 changes: 3 additions & 0 deletions src/Analyzer/Passes/FuseFunctionsPass.cpp
Expand Up @@ -14,6 +14,9 @@
#include <Analyzer/FunctionNode.h>
#include <Analyzer/HashUtils.h>

#include <numeric>


namespace DB
{

Expand Down
1 change: 0 additions & 1 deletion src/Analyzer/examples/query_analyzer.cpp
@@ -1,4 +1,3 @@
#include <iostream>

int main(int argc, char ** argv)
{
Expand Down
1 change: 0 additions & 1 deletion src/Client/ConnectionParameters.cpp
@@ -1,6 +1,5 @@
#include "ConnectionParameters.h"
#include <fstream>
#include <iostream>
#include <Core/Defines.h>
#include <Core/Protocol.h>
#include <Core/Types.h>
Expand Down
1 change: 0 additions & 1 deletion src/Client/ConnectionString.cpp
Expand Up @@ -6,7 +6,6 @@
#include <Poco/URI.h>

#include <array>
#include <iostream>
#include <string>
#include <unordered_map>

Expand Down
4 changes: 2 additions & 2 deletions src/Columns/ColumnObject.cpp
Expand Up @@ -2,17 +2,17 @@
#include <Columns/ColumnObject.h>
#include <Columns/ColumnsNumber.h>
#include <Columns/ColumnArray.h>
#include <Columns/ColumnSparse.h>
#include <DataTypes/ObjectUtils.h>
#include <DataTypes/getLeastSupertype.h>
#include <DataTypes/DataTypeNothing.h>
#include <DataTypes/DataTypeNullable.h>
#include <DataTypes/DataTypeFactory.h>
#include <DataTypes/NestedUtils.h>
#include <Interpreters/castColumn.h>
#include <Interpreters/convertFieldToType.h>
#include <Common/HashTable/HashSet.h>
#include <Processors/Transforms/ColumnGathererTransform.h>
#include <numeric>


namespace DB
{
Expand Down
1 change: 1 addition & 0 deletions src/Columns/tests/gtest_column_sparse.cpp
Expand Up @@ -10,6 +10,7 @@

#include <Common/FieldVisitors.h>


using namespace DB;
static pcg64 rng(randomSeed());

Expand Down
1 change: 0 additions & 1 deletion src/Common/Config/configReadClient.cpp
Expand Up @@ -3,7 +3,6 @@
#include <Poco/Util/LayeredConfiguration.h>
#include "ConfigProcessor.h"
#include <filesystem>
#include <iostream>
#include <base/types.h>

namespace fs = std::filesystem;
Expand Down
1 change: 0 additions & 1 deletion src/Common/CounterInFile.h
Expand Up @@ -4,7 +4,6 @@
#include <sys/file.h>

#include <string>
#include <iostream>
#include <mutex>
#include <filesystem>

Expand Down
1 change: 0 additions & 1 deletion src/Common/DateLUTImpl.cpp
Expand Up @@ -10,7 +10,6 @@
#include <chrono>
#include <cstring>
#include <memory>
#include <iostream>


/// Embedded timezones.
Expand Down
2 changes: 1 addition & 1 deletion src/Common/EventNotifier.h
Expand Up @@ -7,11 +7,11 @@
#include <map>
#include <memory>
#include <utility>
#include <iostream>

#include <base/types.h>
#include <Common/HashTable/Hash.h>


namespace DB
{

Expand Down
1 change: 0 additions & 1 deletion src/Common/FST.cpp
@@ -1,7 +1,6 @@
#include "FST.h"
#include <algorithm>
#include <cassert>
#include <iostream>
#include <memory>
#include <vector>
#include <Common/Exception.h>
Expand Down
2 changes: 1 addition & 1 deletion src/Common/SpaceSaving.h
@@ -1,6 +1,5 @@
#pragma once

#include <iostream>
#include <vector>

#include <boost/range/adaptor/reversed.hpp>
Expand All @@ -19,6 +18,7 @@
#include <IO/ReadHelpers.h>
#include <IO/VarInt.h>


/*
* Implementation of the Filtered Space-Saving for TopK streaming analysis.
* http://www.l2f.inesc-id.pt/~fmmb/wiki/uploads/Work/misnis.ref0a.pdf
Expand Down
1 change: 0 additions & 1 deletion src/Common/StudentTTest.cpp
@@ -1,7 +1,6 @@
#include "StudentTTest.h"

#include <cmath>
#include <iostream>
#include <iomanip>
#include <sstream>
#include <stdexcept>
Expand Down
1 change: 0 additions & 1 deletion src/Common/ThreadPool.cpp
Expand Up @@ -6,7 +6,6 @@
#include <Common/noexcept_scope.h>

#include <cassert>
#include <iostream>
#include <type_traits>

#include <Poco/Util/Application.h>
Expand Down
1 change: 0 additions & 1 deletion src/Common/UnicodeBar.cpp
Expand Up @@ -7,7 +7,6 @@
#include <Common/UnicodeBar.h>
#include <Common/NaNUtils.h>

#include <iostream>

namespace DB
{
Expand Down
7 changes: 1 addition & 6 deletions src/Common/VersionNumber.h
Expand Up @@ -2,9 +2,9 @@

#include <string>
#include <vector>
#include <iostream>
#include <base/types.h>


namespace DB
{

Expand All @@ -27,11 +27,6 @@ struct VersionNumber

std::string toString() const;

friend std::ostream & operator<<(std::ostream & os, const VersionNumber & v)
{
return os << v.toString();
}

private:
using Components = std::vector<Int64>;
Components components;
Expand Down
1 change: 0 additions & 1 deletion src/Common/benchmarks/integer_hash_tables_and_hashes.cpp
@@ -1,7 +1,6 @@
#include <benchmark/benchmark.h>

#include <iomanip>
#include <iostream>
#include <random>
#include <vector>

Expand Down
1 change: 0 additions & 1 deletion src/Common/examples/average.cpp
@@ -1,4 +1,3 @@
#include <iostream>
#include <string>
#include <bit>

Expand Down
1 change: 0 additions & 1 deletion src/Common/examples/chaos_sanitizer.cpp
Expand Up @@ -6,7 +6,6 @@

#include <IO/ReadHelpers.h>

#include <Common/Exception.h>
#include <Common/ThreadFuzzer.h>


Expand Down
2 changes: 1 addition & 1 deletion src/Common/examples/compact_array.cpp
Expand Up @@ -4,11 +4,11 @@
#include <filesystem>
#include <string>
#include <iostream>
#include <fstream>
#include <stdexcept>
#include <cstdlib>
#include <unistd.h>


namespace fs = std::filesystem;

static std::string createTmpPath(const std::string & filename)
Expand Down
2 changes: 1 addition & 1 deletion src/Common/tests/gtest_hash_table.cpp
@@ -1,5 +1,5 @@
#include <iomanip>
#include <iostream>
#include <numeric>

#include <Interpreters/AggregationCommon.h>

Expand Down
1 change: 0 additions & 1 deletion src/Common/tests/gtest_lru_cache.cpp
@@ -1,5 +1,4 @@
#include <iomanip>
#include <iostream>
#include <gtest/gtest.h>
#include <Common/CacheBase.h>

Expand Down
1 change: 0 additions & 1 deletion src/Common/tests/gtest_lru_hash_map.cpp
@@ -1,5 +1,4 @@
#include <iomanip>
#include <iostream>

#include <Common/HashTable/LRUHashMap.h>

Expand Down
1 change: 0 additions & 1 deletion src/Common/tests/gtest_lru_resource_cache.cpp
@@ -1,5 +1,4 @@
#include <iomanip>
#include <iostream>
#include <gtest/gtest.h>
#include <Common/LRUResourceCache.h>

Expand Down
1 change: 0 additions & 1 deletion src/Common/tests/gtest_slru_cache.cpp
@@ -1,5 +1,4 @@
#include <iomanip>
#include <iostream>
#include <gtest/gtest.h>
#include <Common/CacheBase.h>

Expand Down
1 change: 0 additions & 1 deletion src/Common/tests/gtest_thread_pool_limit.cpp
@@ -1,5 +1,4 @@
#include <atomic>
#include <iostream>
#include <Common/ThreadPool.h>
#include <Common/CurrentMetrics.h>

Expand Down
1 change: 0 additions & 1 deletion src/Common/tests/gtest_thread_pool_loop.cpp
@@ -1,5 +1,4 @@
#include <atomic>
#include <iostream>
#include <Common/ThreadPool.h>
#include <Common/CurrentMetrics.h>

Expand Down
1 change: 0 additions & 1 deletion src/Common/tests/gtest_thread_pool_schedule_exception.cpp
@@ -1,4 +1,3 @@
#include <iostream>
#include <stdexcept>
#include <Common/ThreadPool.h>
#include <Common/CurrentMetrics.h>
Expand Down
4 changes: 3 additions & 1 deletion src/Compression/CompressionCodecDeflateQpl.cpp
@@ -1,15 +1,17 @@
#ifdef ENABLE_QPL_COMPRESSION

#include <cstdio>
#include <thread>
#include <Compression/CompressionCodecDeflateQpl.h>
#include <Compression/CompressionFactory.h>
#include <Compression/CompressionInfo.h>
#include <Parsers/ASTIdentifier.h>
#include <Poco/Logger.h>
#include <Common/logger_useful.h>
#include "libaccel_config.h"
#include <Common/MemorySanitizer.h>
#include <base/scope_guard.h>
#include <immintrin.h>


namespace DB
{
Expand Down
1 change: 0 additions & 1 deletion src/Compression/fuzzers/compressed_buffer_fuzzer.cpp
@@ -1,4 +1,3 @@
#include <iostream>
#include <IO/ReadBufferFromMemory.h>
#include <Compression/CompressedReadBuffer.h>
#include <Common/Exception.h>
Expand Down
1 change: 0 additions & 1 deletion src/Compression/fuzzers/delta_decompress_fuzzer.cpp
@@ -1,4 +1,3 @@
#include <iostream>
#include <string>

#include <Compression/ICompressionCodec.h>
Expand Down
1 change: 0 additions & 1 deletion src/Compression/fuzzers/double_delta_decompress_fuzzer.cpp
@@ -1,4 +1,3 @@
#include <iostream>
#include <string>

#include <Compression/ICompressionCodec.h>
Expand Down
1 change: 0 additions & 1 deletion src/Compression/fuzzers/encrypted_decompress_fuzzer.cpp
@@ -1,6 +1,5 @@
#include <cstddef>
#include <cstdint>
#include <iostream>
#include <memory>
#include <string>

Expand Down
1 change: 0 additions & 1 deletion src/Compression/fuzzers/lz4_decompress_fuzzer.cpp
@@ -1,4 +1,3 @@
#include <iostream>
#include <string>

#include <Compression/ICompressionCodec.h>
Expand Down
2 changes: 1 addition & 1 deletion src/Coordination/SnapshotableHashTable.h
Expand Up @@ -6,7 +6,7 @@
#include <unordered_map>
#include <list>
#include <atomic>
#include <iostream>


namespace DB
{
Expand Down
1 change: 0 additions & 1 deletion src/Coordination/SummingStateMachine.cpp
@@ -1,5 +1,4 @@
#include <Coordination/SummingStateMachine.h>
#include <iostream>
#include <cstring>

namespace DB
Expand Down
1 change: 0 additions & 1 deletion src/Coordination/pathUtils.cpp
@@ -1,5 +1,4 @@
#include <Coordination/pathUtils.h>
#include <iostream>

namespace DB
{
Expand Down

0 comments on commit bb57caa

Please sign in to comment.