ClickHouse/dbms/include/DB/DataStreams/GraphiteRollupSortedBlockInputStream.h

215 lines
6.2 KiB
C++
Raw Normal View History

2016-04-24 09:44:47 +00:00
#pragma once
#include <common/logger_useful.h>
#include <DB/Core/Row.h>
#include <DB/Core/ColumnNumbers.h>
#include <DB/DataStreams/MergingSortedBlockInputStream.h>
#include <DB/AggregateFunctions/IAggregateFunction.h>
#include <DB/Columns/ColumnAggregateFunction.h>
#include <DB/Common/OptimizedRegularExpression.h>
namespace DB
{
2017-02-07 19:21:59 +00:00
/** Intended for implementation of "rollup" - aggregation (rounding) of older data
* for a table with Graphite data (Graphite is the system for time series monitoring).
2016-04-24 09:44:47 +00:00
*
2017-02-07 19:21:59 +00:00
* Table with graphite data has at least the folowing columns (accurate to the name):
2016-04-24 09:44:47 +00:00
* Path, Time, Value, Version
*
2017-02-07 19:21:59 +00:00
* Path - name of metric (sensor);
* Time - time of measurement;
* Value - value of measurement;
* Version - a number, that for equal pairs of Path and Time, need to leave only record with maximum version.
2016-04-24 09:44:47 +00:00
*
2017-02-07 19:21:59 +00:00
* Each row in a table correspond to one value of one sensor.
2016-04-24 09:44:47 +00:00
*
2017-02-07 19:21:59 +00:00
* Rollup rules are specified in the following way:
2016-04-24 09:44:47 +00:00
*
* pattern
* regexp
* function
* age -> precision
* age -> precision
* ...
* pattern
* ...
* default
* function
* age -> precision
* ...
*
2017-02-07 19:21:59 +00:00
* regexp - pattern for sensor name
* default - if no pattern has matched
2016-04-24 09:44:47 +00:00
*
2017-02-07 19:21:59 +00:00
* age - minimal data age (in seconds), to start rounding with specified precision.
* precision - rounding precision (in seconds)
2016-04-24 09:44:47 +00:00
*
2017-02-07 19:21:59 +00:00
* function - name of aggregate function to be applied for values, that time was rounded to same.
2016-04-24 09:44:47 +00:00
*
2017-02-07 19:21:59 +00:00
* Example:
2016-04-24 09:44:47 +00:00
*
* <graphite_rollup>
* <pattern>
* <regexp>click_cost</regexp>
* <function>any</function>
* <retention>
* <age>0</age>
* <precision>5</precision>
2016-04-24 09:44:47 +00:00
* </retention>
* <retention>
* <age>86400</age>
* <precision>60</precision>
* </retention>
* </pattern>
* <default>
* <function>max</function>
* <retention>
* <age>0</age>
* <precision>60</precision>
* </retention>
* <retention>
* <age>3600</age>
* <precision>300</precision>
* </retention>
* <retention>
* <age>86400</age>
* <precision>3600</precision>
* </retention>
* </default>
* </graphite_rollup>
*/
namespace Graphite
{
struct Retention
{
UInt32 age;
UInt32 precision;
};
using Retentions = std::vector<Retention>;
struct Pattern
{
std::shared_ptr<OptimizedRegularExpression> regexp;
AggregateFunctionPtr function;
2017-02-07 19:21:59 +00:00
Retentions retentions; /// Must be ordered by 'age' descending.
2016-04-24 09:44:47 +00:00
};
using Patterns = std::vector<Pattern>;
struct Params
{
String path_column_name;
String time_column_name;
String value_column_name;
String version_column_name;
Graphite::Patterns patterns;
};
}
/** Соединяет несколько сортированных потоков в один.
*
* При этом, для каждой группы идущих подряд одинаковых значений столбца path,
* и одинаковых значений time с округлением до некоторой точности
* (где точность округления зависит от набора шаблонов на path
* и количества времени, прошедшего от time до заданного времени),
* оставляет одну строку,
* выполняя округление времени,
* слияние значений value, используя заданные агрегатные функции,
* а также оставляя максимальное значение столбца version.
*/
class GraphiteRollupSortedBlockInputStream : public MergingSortedBlockInputStream
{
public:
GraphiteRollupSortedBlockInputStream(
BlockInputStreams inputs_, const SortDescription & description_, size_t max_block_size_,
const Graphite::Params & params, time_t time_of_merge)
: MergingSortedBlockInputStream(inputs_, description_, max_block_size_),
params(params), time_of_merge(time_of_merge)
{
}
String getName() const override { return "GraphiteRollupSorted"; }
String getID() const override
{
std::stringstream res;
res << "GraphiteRollupSorted(inputs";
for (size_t i = 0; i < children.size(); ++i)
res << ", " << children[i]->getID();
res << ", description";
for (size_t i = 0; i < description.size(); ++i)
res << ", " << description[i].getID();
res << ")";
return res.str();
}
~GraphiteRollupSortedBlockInputStream()
{
if (current_pattern)
current_pattern->function->destroy(place_for_aggregate_state.data());
}
protected:
Block readImpl() override;
private:
Logger * log = &Logger::get("GraphiteRollupSortedBlockInputStream");
const Graphite::Params params;
size_t path_column_num;
size_t time_column_num;
size_t value_column_num;
size_t version_column_num;
2017-02-07 19:21:59 +00:00
/// All columns other than 'time', 'value', 'version'. They are unmodified during rollup.
2016-04-24 09:44:47 +00:00
ColumnNumbers unmodified_column_numbers;
time_t time_of_merge;
2017-02-07 19:21:59 +00:00
/// All data has been read.
2016-04-24 09:44:47 +00:00
bool finished = false;
2017-02-07 19:21:59 +00:00
/// This object owns a column while 'current_path' references to it.
2016-04-24 19:46:37 +00:00
SharedBlockPtr owned_current_block;
2016-04-24 09:44:47 +00:00
bool is_first = true;
StringRef current_path;
time_t current_time;
StringRef next_path;
time_t next_time;
UInt64 current_max_version = 0;
const Graphite::Pattern * current_pattern = nullptr;
std::vector<char> place_for_aggregate_state;
const Graphite::Pattern * selectPatternForPath(StringRef path) const;
UInt32 selectPrecision(const Graphite::Retentions & retentions, time_t time) const;
template <typename TSortCursor>
void merge(ColumnPlainPtrs & merged_columns, std::priority_queue<TSortCursor> & queue);
/// Вставить значения в результирующие столбцы, которые не будут меняться в дальнейшем.
template <class TSortCursor>
void startNextRow(ColumnPlainPtrs & merged_columns, TSortCursor & cursor);
/// Вставить в результирующие столбцы вычисленные значения time, value, version по последней группе строк.
void finishCurrentRow(ColumnPlainPtrs & merged_columns);
/// Обновить состояние агрегатной функции новым значением value.
template <class TSortCursor>
void accumulateRow(TSortCursor & cursor);
};
}