From 93890423f19787f0746410d2063f0be06c5e12c8 Mon Sep 17 00:00:00 2001 From: Alexey Milovidov Date: Sun, 26 Mar 2017 04:20:25 +0300 Subject: [PATCH] Fixed zero-width spaces [#CLICKHOUSE-3]. find dbms -name '*.h' -or -name '*.cpp' | xargs grep -l $'\xe2\x80\x8b' | xargs sed -i 's/'$'\xe2\x80\x8b''//g' --- dbms/src/Columns/ColumnAggregateFunction.cpp | 4 ++-- dbms/src/Common/tests/int_hashes_perf.cpp | 2 +- dbms/src/Core/BlockInfo.cpp | 4 ++-- dbms/src/DataStreams/AddingDefaultBlockOutputStream.cpp | 2 +- dbms/src/DataStreams/AggregatingSortedBlockInputStream.cpp | 2 +- dbms/src/DataStreams/GraphiteRollupSortedBlockInputStream.cpp | 2 +- dbms/src/DataStreams/JSONEachRowRowInputStream.cpp | 2 +- dbms/src/DataStreams/PrettyBlockOutputStream.cpp | 2 +- dbms/src/DataStreams/PrettyCompactBlockOutputStream.cpp | 2 +- dbms/src/DataStreams/PrettySpaceBlockOutputStream.cpp | 2 +- dbms/src/DataStreams/TSKVRowInputStream.cpp | 2 +- dbms/src/DataStreams/TotalsHavingBlockInputStream.cpp | 4 ++-- dbms/src/Functions/tests/logical_functions_performance.cpp | 2 +- 13 files changed, 16 insertions(+), 16 deletions(-) diff --git a/dbms/src/Columns/ColumnAggregateFunction.cpp b/dbms/src/Columns/ColumnAggregateFunction.cpp index f5334441ef..de992958dd 100644 --- a/dbms/src/Columns/ColumnAggregateFunction.cpp +++ b/dbms/src/Columns/ColumnAggregateFunction.cpp @@ -46,14 +46,14 @@ ColumnPtr ColumnAggregateFunction::convertToValues() const * Due to the presence of WITH TOTALS, during aggregation the states of this aggregate function will be stored * in the ColumnAggregateFunction column of type * AggregateFunction(quantileTimingState(0.5), UInt64). - * Then, in `TotalsHavingBlockInputStream`, it will be called `convertToValues` ​​method, + * Then, in `TotalsHavingBlockInputStream`, it will be called `convertToValues` method, * to get the "ready" values. * But it just converts a column of type * `AggregateFunction(quantileTimingState(0.5), UInt64)` * into `AggregateFunction(quantileTiming(0.5), UInt64)` * - in the same states. * - * Then `finalizeAggregation` function will be calculated, which will call `convertToValues` ​​already on the result. + * Then `finalizeAggregation` function will be calculated, which will call `convertToValues` already on the result. * And this converts a column of type * AggregateFunction(quantileTiming(0.5), UInt64) * into UInt16 - already finished result of `quantileTiming`. diff --git a/dbms/src/Common/tests/int_hashes_perf.cpp b/dbms/src/Common/tests/int_hashes_perf.cpp index 3f7f8d6f25..2765b95d28 100644 --- a/dbms/src/Common/tests/int_hashes_perf.cpp +++ b/dbms/src/Common/tests/int_hashes_perf.cpp @@ -214,7 +214,7 @@ void report(const char * name, size_t n, double elapsed, UInt64 tsc_diff, size_t template static inline void test(size_t n, const UInt64 * data, const char * name) { - /// throughput. Calculations of hash functions from different values ​​may overlap. + /// throughput. Calculations of hash functions from different values may overlap. { Stopwatch watch; diff --git a/dbms/src/Core/BlockInfo.cpp b/dbms/src/Core/BlockInfo.cpp index 885de8d7cd..d79b5aeef2 100644 --- a/dbms/src/Core/BlockInfo.cpp +++ b/dbms/src/Core/BlockInfo.cpp @@ -17,7 +17,7 @@ namespace ErrorCodes } -/// Write values ​​in binary form. NOTE: You could use protobuf, but it would be overkill for this case. +/// Write values in binary form. NOTE: You could use protobuf, but it would be overkill for this case. void BlockInfo::write(WriteBuffer & out) const { /// Set of pairs `FIELD_NUM`, value in binary form. Then 0. @@ -31,7 +31,7 @@ void BlockInfo::write(WriteBuffer & out) const writeVarUInt(0, out); } -/// Read values ​​in binary form. +/// Read values in binary form. void BlockInfo::read(ReadBuffer & in) { UInt64 field_num = 0; diff --git a/dbms/src/DataStreams/AddingDefaultBlockOutputStream.cpp b/dbms/src/DataStreams/AddingDefaultBlockOutputStream.cpp index fe6a598354..e8192972da 100644 --- a/dbms/src/DataStreams/AddingDefaultBlockOutputStream.cpp +++ b/dbms/src/DataStreams/AddingDefaultBlockOutputStream.cpp @@ -8,7 +8,7 @@ void AddingDefaultBlockOutputStream::write(const DB::Block & block) { Block res = block; - /// Computes explicitly specified values ​​(in column_defaults) by default. + /// Computes explicitly specified values (in column_defaults) by default. /** @todo if somehow block does not contain values for implicitly-defaulted columns that are prerequisites * for explicitly-defaulted ones, exception will be thrown during evaluating such columns * (implicitly-defaulted columns are evaluated on the line after following one. */ diff --git a/dbms/src/DataStreams/AggregatingSortedBlockInputStream.cpp b/dbms/src/DataStreams/AggregatingSortedBlockInputStream.cpp index 34dc8735c2..a2c6087ed3 100644 --- a/dbms/src/DataStreams/AggregatingSortedBlockInputStream.cpp +++ b/dbms/src/DataStreams/AggregatingSortedBlockInputStream.cpp @@ -100,7 +100,7 @@ void AggregatingSortedBlockInputStream::merge(ColumnPlainPtrs & merged_columns, { current_key.swap(next_key); - /// We will write the data for the group. We copy the values ​​of ordinary columns. + /// We will write the data for the group. We copy the values of ordinary columns. for (size_t i = 0, size = column_numbers_not_to_aggregate.size(); i < size; ++i) { size_t j = column_numbers_not_to_aggregate[i]; diff --git a/dbms/src/DataStreams/GraphiteRollupSortedBlockInputStream.cpp b/dbms/src/DataStreams/GraphiteRollupSortedBlockInputStream.cpp index 1dc9cc1fe6..fef23628e5 100644 --- a/dbms/src/DataStreams/GraphiteRollupSortedBlockInputStream.cpp +++ b/dbms/src/DataStreams/GraphiteRollupSortedBlockInputStream.cpp @@ -232,7 +232,7 @@ void GraphiteRollupSortedBlockInputStream::startNextRow(ColumnPlainPtrs & merged void GraphiteRollupSortedBlockInputStream::finishCurrentRow(ColumnPlainPtrs & merged_columns) { - /// Insert calculated values ​​of the columns `time`, `value`, `version`. + /// Insert calculated values of the columns `time`, `value`, `version`. merged_columns[time_column_num]->insert(UInt64(current_time_rounded)); merged_columns[version_column_num]->insert(current_max_version); diff --git a/dbms/src/DataStreams/JSONEachRowRowInputStream.cpp b/dbms/src/DataStreams/JSONEachRowRowInputStream.cpp index f2839ab615..6f6e2d11d9 100644 --- a/dbms/src/DataStreams/JSONEachRowRowInputStream.cpp +++ b/dbms/src/DataStreams/JSONEachRowRowInputStream.cpp @@ -68,7 +68,7 @@ bool JSONEachRowRowInputStream::read(Block & block) size_t columns = block.columns(); - /// Set of columns for which the values ​​were read. The rest will be filled with default values. + /// Set of columns for which the values were read. The rest will be filled with default values. /// TODO Ability to provide your DEFAULTs. bool read_columns[columns]; memset(read_columns, 0, columns); diff --git a/dbms/src/DataStreams/PrettyBlockOutputStream.cpp b/dbms/src/DataStreams/PrettyBlockOutputStream.cpp index d3baad8319..f0cc1ac922 100644 --- a/dbms/src/DataStreams/PrettyBlockOutputStream.cpp +++ b/dbms/src/DataStreams/PrettyBlockOutputStream.cpp @@ -101,7 +101,7 @@ void PrettyBlockOutputStream::write(const Block & block_) return; } - /// We will insert here columns with the calculated values ​​of visible lengths. + /// We will insert here columns with the calculated values of visible lengths. Block block = block_; size_t rows = block.rows(); diff --git a/dbms/src/DataStreams/PrettyCompactBlockOutputStream.cpp b/dbms/src/DataStreams/PrettyCompactBlockOutputStream.cpp index 009f8dab16..7eec893201 100644 --- a/dbms/src/DataStreams/PrettyCompactBlockOutputStream.cpp +++ b/dbms/src/DataStreams/PrettyCompactBlockOutputStream.cpp @@ -118,7 +118,7 @@ void PrettyCompactBlockOutputStream::write(const Block & block_) return; } - /// We will insert columns here with the calculated values ​​of visible lengths. + /// We will insert columns here with the calculated values of visible lengths. Block block = block_; size_t rows = block.rows(); diff --git a/dbms/src/DataStreams/PrettySpaceBlockOutputStream.cpp b/dbms/src/DataStreams/PrettySpaceBlockOutputStream.cpp index 0e61c9a87a..02c9b91ad3 100644 --- a/dbms/src/DataStreams/PrettySpaceBlockOutputStream.cpp +++ b/dbms/src/DataStreams/PrettySpaceBlockOutputStream.cpp @@ -15,7 +15,7 @@ void PrettySpaceBlockOutputStream::write(const Block & block_) return; } - /// We will insert here columns with the calculated values ​​of visible lengths. + /// We will insert here columns with the calculated values of visible lengths. Block block = block_; size_t rows = block.rows(); diff --git a/dbms/src/DataStreams/TSKVRowInputStream.cpp b/dbms/src/DataStreams/TSKVRowInputStream.cpp index 26a1375ff5..7821a51daa 100644 --- a/dbms/src/DataStreams/TSKVRowInputStream.cpp +++ b/dbms/src/DataStreams/TSKVRowInputStream.cpp @@ -92,7 +92,7 @@ bool TSKVRowInputStream::read(Block & block) size_t columns = block.columns(); - /// Set of columns for which the values ​​were read. The rest will be filled with default values. + /// Set of columns for which the values were read. The rest will be filled with default values. /// TODO Ability to provide your DEFAULTs. bool read_columns[columns]; memset(read_columns, 0, columns); diff --git a/dbms/src/DataStreams/TotalsHavingBlockInputStream.cpp b/dbms/src/DataStreams/TotalsHavingBlockInputStream.cpp index 6efcdff51d..a271b27933 100644 --- a/dbms/src/DataStreams/TotalsHavingBlockInputStream.cpp +++ b/dbms/src/DataStreams/TotalsHavingBlockInputStream.cpp @@ -86,7 +86,7 @@ Block TotalsHavingBlockInputStream::readImpl() { block = children[0]->read(); - /// Block with values ​​not included in `max_rows_to_group_by`. We'll postpone it. + /// Block with values not included in `max_rows_to_group_by`. We'll postpone it. if (overflow_row && block && block.info.is_overflows) { overflow_aggregates = block; @@ -125,7 +125,7 @@ Block TotalsHavingBlockInputStream::readImpl() IColumn::Filter & filter = filter_column->getData(); - /// Add values ​​to `totals` (if it was not already done). + /// Add values to `totals` (if it was not already done). if (totals_mode == TotalsMode::BEFORE_HAVING) addToTotals(current_totals, block, nullptr); else diff --git a/dbms/src/Functions/tests/logical_functions_performance.cpp b/dbms/src/Functions/tests/logical_functions_performance.cpp index 3cecf79c38..d30d25798c 100644 --- a/dbms/src/Functions/tests/logical_functions_performance.cpp +++ b/dbms/src/Functions/tests/logical_functions_performance.cpp @@ -69,7 +69,7 @@ struct AssociativeOperationImpl AssociativeOperationImpl(UInt8ColumnPtrs & in) : vec(in[in.size() - N]->getData()), continuation(in) {} - /// Returns a combination of values ​​in the i-th row of all columns stored in the constructor. + /// Returns a combination of values in the i-th row of all columns stored in the constructor. inline UInt8 apply(size_t i) const { //return vec[i] ? continuation.apply(i) : 0; -- GitLab