ClickHouse/dbms/src/Storages/WindowView/StorageWindowView.cpp

941 lines
36 KiB
C++
Raw Normal View History

2020-01-14 03:07:31 +00:00
#include <AggregateFunctions/AggregateFunctionFactory.h>
#include <Columns/ColumnTuple.h>
#include <Columns/ColumnsNumber.h>
2020-02-20 17:30:58 +00:00
#include <DataStreams/AddingConstColumnBlockInputStream.h>
2020-01-14 03:07:31 +00:00
#include <DataStreams/BlocksBlockInputStream.h>
2020-02-12 17:39:57 +00:00
#include <DataStreams/ExpressionBlockInputStream.h>
#include <DataStreams/FilterBlockInputStream.h>
2020-01-14 03:07:31 +00:00
#include <DataStreams/IBlockOutputStream.h>
#include <DataStreams/MaterializingBlockInputStream.h>
#include <DataStreams/NullBlockInputStream.h>
#include <DataStreams/OneBlockInputStream.h>
#include <DataStreams/SquashingBlockInputStream.h>
#include <DataStreams/copyData.h>
#include <DataTypes/DataTypeArray.h>
#include <DataTypes/DataTypeDateTime.h>
#include <DataTypes/DataTypesNumber.h>
2020-02-12 17:39:57 +00:00
#include <Functions/FunctionFactory.h>
2020-01-14 03:07:31 +00:00
#include <Functions/FunctionsWindow.h>
#include <Interpreters/AddDefaultDatabaseVisitor.h>
#include <Interpreters/Context.h>
#include <Interpreters/InDepthNodeVisitor.h>
2020-02-12 17:39:57 +00:00
#include <Interpreters/InterpreterAlterQuery.h>
2020-01-14 03:07:31 +00:00
#include <Interpreters/InterpreterDropQuery.h>
#include <Interpreters/InterpreterSelectQuery.h>
#include <Interpreters/getTableExpressions.h>
2020-02-12 17:39:57 +00:00
#include <Parsers/ASTAlterQuery.h>
#include <Parsers/ASTAssignment.h>
#include <Parsers/ASTAsterisk.h>
2020-01-14 03:07:31 +00:00
#include <Parsers/ASTCreateQuery.h>
#include <Parsers/ASTDropQuery.h>
#include <Parsers/ASTIdentifier.h>
#include <Parsers/ASTLiteral.h>
#include <Parsers/ASTSelectQuery.h>
#include <Parsers/ASTSubquery.h>
#include <Parsers/ASTTablesInSelectQuery.h>
#include <Parsers/ASTWatchQuery.h>
#include <Parsers/formatAST.h>
#include <Storages/StorageFactory.h>
2020-02-14 08:07:03 +00:00
#include <boost/lexical_cast.hpp>
2020-01-14 03:07:31 +00:00
#include <Common/typeid_cast.h>
2020-02-17 05:06:03 +00:00
#include <Storages/WindowView/BlocksListInputStream.h>
2020-01-14 03:07:31 +00:00
#include <Storages/WindowView/StorageWindowView.h>
#include <Storages/WindowView/WindowViewBlockInputStream.h>
#include <Storages/WindowView/WindowViewProxyStorage.h>
namespace DB
{
namespace ErrorCodes
{
extern const int LOGICAL_ERROR;
extern const int INCORRECT_QUERY;
extern const int TABLE_WAS_NOT_DROPPED;
extern const int QUERY_IS_NOT_SUPPORTED_IN_WINDOW_VIEW;
extern const int SUPPORT_IS_DISABLED;
extern const int NUMBER_OF_ARGUMENTS_DOESNT_MATCH;
2020-02-14 08:07:03 +00:00
extern const int CANNOT_PARSE_TEXT;
2020-01-14 03:07:31 +00:00
}
namespace
{
const auto RESCHEDULE_MS = 500;
class ParserStageMergeableOneMatcher
{
public:
using Visitor = InDepthNodeVisitor<ParserStageMergeableOneMatcher, true>;
struct Data
{
ASTPtr window_function;
String window_column_name;
bool is_tumble = false;
bool is_hop = false;
};
static bool needChildVisit(ASTPtr & node, const ASTPtr &)
{
if (node->as<ASTFunction>())
return false;
return true;
}
static void visit(ASTPtr & ast, Data & data)
{
if (const auto * t = ast->as<ASTFunction>())
visit(*t, ast, data);
}
private:
static void visit(const ASTFunction & node, ASTPtr & node_ptr, Data & data)
{
if (node.name == "TUMBLE")
{
2020-01-14 09:53:52 +00:00
if (!data.window_function)
2020-01-14 03:07:31 +00:00
{
data.is_tumble = true;
data.window_column_name = node.getColumnName();
data.window_function = node.clone();
}
else if (serializeAST(node) != serializeAST(*data.window_function))
throw Exception("WINDOW VIEW only support ONE WINDOW FUNCTION", ErrorCodes::QUERY_IS_NOT_SUPPORTED_IN_WINDOW_VIEW);
}
else if (node.name == "HOP")
{
2020-01-14 09:53:52 +00:00
if (!data.window_function)
2020-01-14 03:07:31 +00:00
{
data.is_hop = true;
data.window_function = node.clone();
auto ptr_ = node.clone();
std::static_pointer_cast<ASTFunction>(ptr_)->setAlias("");
auto arrayJoin = makeASTFunction("arrayJoin", ptr_);
arrayJoin->alias = node.alias;
node_ptr = arrayJoin;
2020-02-17 05:06:03 +00:00
data.window_column_name = arrayJoin->getColumnName();
2020-01-14 03:07:31 +00:00
}
2020-01-14 09:53:52 +00:00
else if (serializeAST(node) != serializeAST(*data.window_function))
2020-01-14 03:07:31 +00:00
throw Exception("WINDOW VIEW only support ONE WINDOW FUNCTION", ErrorCodes::QUERY_IS_NOT_SUPPORTED_IN_WINDOW_VIEW);
}
}
};
2020-02-14 08:55:56 +00:00
2020-02-17 05:06:03 +00:00
class ParserProcTimeFinalMatcher
{
public:
using Visitor = InDepthNodeVisitor<ParserProcTimeFinalMatcher, true>;
struct Data
{
bool is_proctime_tumble = false;
String window_column_name;
};
static bool needChildVisit(ASTPtr &, const ASTPtr &)
{
return true;
}
static void visit(ASTPtr & ast, Data & data)
{
if (const auto * t = ast->as<ASTFunction>())
visit(*t, ast, data);
}
private:
static void visit(const ASTFunction & node, ASTPtr & node_ptr, Data & data)
{
if (node.name == "TUMBLE")
{
if (const auto * t = node.arguments->children[0]->as<ASTFunction>(); t && t->name == "now")
{
data.is_proctime_tumble = true;
node_ptr->children[0]->children[0] = std::make_shared<ASTIdentifier>("____timestamp");
data.window_column_name = node.getColumnName();
}
}
}
};
2020-02-14 08:07:03 +00:00
static inline IntervalKind strToIntervalKind(const String& interval_str)
{
if (interval_str == "Second")
return IntervalKind::Second;
else if (interval_str == "Minute")
return IntervalKind::Minute;
else if (interval_str == "Hour")
return IntervalKind::Hour;
else if (interval_str == "Day")
return IntervalKind::Day;
else if (interval_str == "Week")
return IntervalKind::Week;
else if (interval_str == "Month")
return IntervalKind::Month;
else if (interval_str == "Quarter")
return IntervalKind::Quarter;
else if (interval_str == "Year")
return IntervalKind::Year;
__builtin_unreachable();
}
2020-02-12 17:39:57 +00:00
static inline String generateInnerTableName(const String & table_name) { return ".inner." + table_name; }
static ASTPtr generateDeleteRetiredQuery(StorageID inner_table_id, UInt32 timestamp)
{
auto function_equal = makeASTFunction(
"less", std::make_shared<ASTIdentifier>("____w_end"), std::make_shared<ASTLiteral>(timestamp));
auto alterCommand = std::make_shared<ASTAlterCommand>();
alterCommand->type = ASTAlterCommand::DELETE;
alterCommand->predicate = function_equal;
alterCommand->children.push_back(alterCommand->predicate);
auto alterCommandList = std::make_shared<ASTAlterCommandList>();
alterCommandList->add(alterCommand);
auto alterQuery = std::make_shared<ASTAlterQuery>();
alterQuery->database = inner_table_id.database_name;
alterQuery->table = inner_table_id.table_name;
alterQuery->set(alterQuery->command_list, alterCommandList);
return alterQuery;
}
static std::shared_ptr<ASTSelectQuery> generateFetchColumnsQuery(const StorageID & inner_storage)
{
auto res_query = std::make_shared<ASTSelectQuery>();
auto select = std::make_shared<ASTExpressionList>();
select->children.push_back(std::make_shared<ASTAsterisk>());
res_query->setExpression(ASTSelectQuery::Expression::SELECT, select);
auto tableInSelectQuery = std::make_shared<ASTTablesInSelectQuery>();
auto tableInSelectQueryElement = std::make_shared<ASTTablesInSelectQueryElement>();
res_query->setExpression(ASTSelectQuery::Expression::TABLES, std::make_shared<ASTTablesInSelectQuery>());
auto tables = res_query->tables();
auto tables_elem = std::make_shared<ASTTablesInSelectQueryElement>();
auto table_expr = std::make_shared<ASTTableExpression>();
tables->children.push_back(tables_elem);
tables_elem->table_expression = table_expr;
tables_elem->children.push_back(table_expr);
table_expr->database_and_table_name = createTableIdentifier(inner_storage.database_name, inner_storage.table_name);
table_expr->children.push_back(table_expr->database_and_table_name);
return res_query;
}
2020-01-14 03:07:31 +00:00
}
static void extractDependentTable(ASTSelectQuery & query, String & select_database_name, String & select_table_name)
{
auto db_and_table = getDatabaseAndTable(query, 0);
ASTPtr subquery = extractTableExpression(query, 0);
if (!db_and_table && !subquery)
return;
if (db_and_table)
{
select_table_name = db_and_table->table;
if (db_and_table->database.empty())
{
db_and_table->database = select_database_name;
AddDefaultDatabaseVisitor visitor(select_database_name);
visitor.visit(query);
}
else
select_database_name = db_and_table->database;
}
else if (auto * ast_select = subquery->as<ASTSelectWithUnionQuery>())
{
if (ast_select->list_of_selects->children.size() != 1)
throw Exception("UNION is not supported for WINDOW VIEW", ErrorCodes::QUERY_IS_NOT_SUPPORTED_IN_WINDOW_VIEW);
auto & inner_query = ast_select->list_of_selects->children.at(0);
extractDependentTable(inner_query->as<ASTSelectQuery &>(), select_database_name, select_table_name);
}
else
throw Exception(
"Logical error while creating StorageWindowView."
" Could not retrieve table name from select query.",
DB::ErrorCodes::LOGICAL_ERROR);
}
void StorageWindowView::checkTableCanBeDropped() const
{
2020-01-24 02:45:45 +00:00
auto table_id = getStorageID();
Dependencies dependencies = global_context.getDependencies(table_id);
2020-01-14 03:07:31 +00:00
if (!dependencies.empty())
{
2020-01-24 02:45:45 +00:00
StorageID dependent_table_id = dependencies.front();
throw Exception("Table has dependency " + dependent_table_id.getNameForLogs(), ErrorCodes::TABLE_WAS_NOT_DROPPED);
2020-01-14 03:07:31 +00:00
}
}
2020-02-12 17:39:57 +00:00
static void executeDropQuery(ASTDropQuery::Kind kind, Context & global_context, const StorageID & target_table_id)
{
if (global_context.tryGetTable(target_table_id))
{
auto drop_query = std::make_shared<ASTDropQuery>();
drop_query->database = target_table_id.database_name;
drop_query->table = target_table_id.table_name;
drop_query->kind = kind;
ASTPtr ast_drop_query = drop_query;
InterpreterDropQuery drop_interpreter(ast_drop_query, global_context);
drop_interpreter.execute();
}
}
2020-01-14 03:07:31 +00:00
void StorageWindowView::drop(TableStructureWriteLockHolder &)
{
2020-01-24 02:45:45 +00:00
auto table_id = getStorageID();
global_context.removeDependency(select_table_id, table_id);
2020-01-14 03:07:31 +00:00
2020-02-14 08:07:03 +00:00
if (!inner_table_id.empty())
2020-02-12 17:39:57 +00:00
executeDropQuery(ASTDropQuery::Kind::Drop, global_context, inner_table_id);
2020-01-14 03:07:31 +00:00
std::lock_guard lock(mutex);
is_dropped = true;
condition.notify_all();
}
2020-02-17 08:18:27 +00:00
void StorageWindowView::truncate(const ASTPtr &, const Context &, TableStructureWriteLockHolder &)
{
if (!inner_table_id.empty())
executeDropQuery(ASTDropQuery::Kind::Truncate, global_context, inner_table_id);
else
{
std::lock_guard lock(mutex);
mergeable_blocks = std::make_shared<std::list<BlocksListPtr>>();
}
}
bool StorageWindowView::optimize(const ASTPtr & query, const ASTPtr & partition, bool final, bool deduplicate, const Context & context)
{
if (inner_table_id.empty())
throw Exception(
"OPTIMIZE only supported when creating WINDOW VIEW within INNER table.", ErrorCodes::INCORRECT_QUERY);
return getInnerStorage()->optimize(query, partition, final, deduplicate, context);
}
inline void StorageWindowView::cleanCache()
2020-02-12 17:39:57 +00:00
{
//delete fired blocks
UInt32 timestamp_now = std::time(nullptr);
UInt32 w_lower_bound = getWindowLowerBound(timestamp_now, -1);
2020-02-14 08:55:56 +00:00
if (watermark_num_units != 0)
2020-02-14 08:07:03 +00:00
w_lower_bound = getWatermark(w_lower_bound);
if (!inner_table_id.empty())
2020-02-12 17:39:57 +00:00
{
auto sql = generateDeleteRetiredQuery(inner_table_id, w_lower_bound);
InterpreterAlterQuery alt_query(sql, global_context);
alt_query.execute();
}
else
{
std::lock_guard lock(mutex);
for (BlocksListPtr mergeable_block : *mergeable_blocks)
{
mergeable_block->remove_if([&w_lower_bound](Block & block_)
{
auto & column_ = block_.getByName("____w_end").column;
const auto & data = static_cast<const ColumnUInt32 &>(*column_).getData();
for (size_t i = 0; i < column_->size(); ++i)
{
if (data[i] >= w_lower_bound)
return false;
}
return true;
});
}
mergeable_blocks->remove_if([](BlocksListPtr & ptr) { return ptr->size() == 0; });
}
2020-02-20 17:30:58 +00:00
{
std::lock_guard lock(fire_signal_mutex);
watch_streams.remove_if([](std::weak_ptr<WindowViewBlockInputStream> & ptr) { return ptr.expired(); });
}
2020-02-12 17:39:57 +00:00
}
2020-02-14 08:07:03 +00:00
inline void StorageWindowView::flushToTable(UInt32 timestamp_)
2020-01-14 03:07:31 +00:00
{
//write into dependent table
2020-02-17 05:06:03 +00:00
StoragePtr target_table = getTargetStorage();
2020-02-14 08:07:03 +00:00
auto _blockInputStreamPtr = getNewBlocksInputStreamPtr(timestamp_);
2020-01-14 03:07:31 +00:00
auto _lock = target_table->lockStructureForShare(true, global_context.getCurrentQueryId());
auto stream = target_table->write(getInnerQuery(), global_context);
copyData(*_blockInputStreamPtr, *stream);
}
2020-02-12 17:39:57 +00:00
std::shared_ptr<ASTCreateQuery> StorageWindowView::generateInnerTableCreateQuery(const ASTCreateQuery & inner_create_query, const String & database_name, const String & table_name)
{
/// We will create a query to create an internal table.
auto manual_create_query = std::make_shared<ASTCreateQuery>();
manual_create_query->database = database_name;
manual_create_query->table = table_name;
auto new_columns_list = std::make_shared<ASTColumns>();
auto sample_block_
2020-02-17 05:06:03 +00:00
= InterpreterSelectQuery(getInnerQuery(), global_context, getParentStorage(), SelectQueryOptions(QueryProcessingStage::WithMergeableState))
2020-02-12 17:39:57 +00:00
.getSampleBlock();
auto columns_list = std::make_shared<ASTExpressionList>();
2020-02-17 05:06:03 +00:00
if (is_proctime_tumble)
{
auto column_window = std::make_shared<ASTColumnDeclaration>();
column_window->name = window_column_name;
column_window->type
= makeASTFunction("Tuple", std::make_shared<ASTIdentifier>("DateTime"), std::make_shared<ASTIdentifier>("DateTime"));
columns_list->children.push_back(column_window);
}
2020-02-12 17:39:57 +00:00
for (auto & column_ : sample_block_.getColumnsWithTypeAndName())
{
ParserIdentifierWithOptionalParameters parser;
String sql = column_.type->getName();
ASTPtr ast = parseQuery(parser, sql.data(), sql.data() + sql.size(), "data type", 0);
auto column_dec = std::make_shared<ASTColumnDeclaration>();
column_dec->name = column_.name;
column_dec->type = ast;
columns_list->children.push_back(column_dec);
}
2020-02-17 05:06:03 +00:00
auto column_wend = std::make_shared<ASTColumnDeclaration>();
column_wend->name = "____w_end";
column_wend->type = std::make_shared<ASTIdentifier>("DateTime");
columns_list->children.push_back(column_wend);
2020-02-12 17:39:57 +00:00
new_columns_list->set(new_columns_list->columns, columns_list);
manual_create_query->set(manual_create_query->columns_list, new_columns_list);
manual_create_query->set(manual_create_query->storage, inner_create_query.storage->ptr());
return manual_create_query;
}
2020-02-14 08:07:03 +00:00
inline UInt32 StorageWindowView::getWindowLowerBound(UInt32 time_sec, int window_id_skew)
2020-02-12 17:39:57 +00:00
{
switch (window_kind)
{
#define CASE_WINDOW_KIND(KIND) \
case IntervalKind::KIND: \
{ \
UInt32 res = ToStartOfTransform<IntervalKind::KIND>::execute(time_sec, window_num_units, time_zone); \
if (window_id_skew != 0) \
return AddTime<IntervalKind::KIND>::execute(res, window_id_skew * window_num_units, time_zone); \
else \
return res; \
}
CASE_WINDOW_KIND(Second)
CASE_WINDOW_KIND(Minute)
CASE_WINDOW_KIND(Hour)
CASE_WINDOW_KIND(Day)
CASE_WINDOW_KIND(Week)
CASE_WINDOW_KIND(Month)
CASE_WINDOW_KIND(Quarter)
CASE_WINDOW_KIND(Year)
#undef CASE_WINDOW_KIND
}
__builtin_unreachable();
}
2020-02-14 08:07:03 +00:00
inline UInt32 StorageWindowView::getWindowUpperBound(UInt32 time_sec, int window_id_skew)
2020-01-14 03:07:31 +00:00
{
switch (window_kind)
{
#define CASE_WINDOW_KIND(KIND) \
case IntervalKind::KIND: \
{ \
UInt32 start = ToStartOfTransform<IntervalKind::KIND>::execute(time_sec, window_num_units, time_zone); \
2020-02-12 17:39:57 +00:00
UInt32 res = AddTime<IntervalKind::KIND>::execute(start, window_num_units, time_zone); \
if (window_id_skew != 0) \
return AddTime<IntervalKind::KIND>::execute(res, window_id_skew * window_num_units, time_zone); \
else \
return res; \
2020-01-14 03:07:31 +00:00
}
2020-01-14 16:24:26 +00:00
CASE_WINDOW_KIND(Second)
CASE_WINDOW_KIND(Minute)
CASE_WINDOW_KIND(Hour)
CASE_WINDOW_KIND(Day)
CASE_WINDOW_KIND(Week)
CASE_WINDOW_KIND(Month)
CASE_WINDOW_KIND(Quarter)
CASE_WINDOW_KIND(Year)
2020-01-14 03:07:31 +00:00
#undef CASE_WINDOW_KIND
}
__builtin_unreachable();
}
2020-02-14 08:07:03 +00:00
inline UInt32 StorageWindowView::getWatermark(UInt32 time_sec)
{
switch (watermark_kind)
{
#define CASE_WINDOW_KIND(KIND) \
case IntervalKind::KIND: \
{ \
return AddTime<IntervalKind::KIND>::execute(time_sec, watermark_num_units, time_zone); \
}
CASE_WINDOW_KIND(Second)
CASE_WINDOW_KIND(Minute)
CASE_WINDOW_KIND(Hour)
CASE_WINDOW_KIND(Day)
CASE_WINDOW_KIND(Week)
CASE_WINDOW_KIND(Month)
CASE_WINDOW_KIND(Quarter)
CASE_WINDOW_KIND(Year)
#undef CASE_WINDOW_KIND
}
__builtin_unreachable();
}
inline void StorageWindowView::addFireSignal(UInt32 timestamp_)
{
if (!target_table_id.empty())
fire_signal.push_back(timestamp_);
2020-02-20 17:30:58 +00:00
for (auto & watch_stream : watch_streams)
2020-02-14 08:07:03 +00:00
{
2020-02-20 17:30:58 +00:00
if (auto watch_stream_ = watch_stream.lock())
watch_stream_->addFireSignal(timestamp_);
2020-02-14 08:07:03 +00:00
}
condition.notify_all();
}
2020-02-17 08:18:27 +00:00
void StorageWindowView::threadFuncCleanCache()
2020-02-12 17:39:57 +00:00
{
while (!shutdown_called)
{
try
{
2020-02-17 08:18:27 +00:00
cleanCache();
sleep(clean_interval);
2020-02-12 17:39:57 +00:00
}
catch (...)
{
tryLogCurrentException(__PRETTY_FUNCTION__);
break;
}
}
if (!shutdown_called)
2020-02-17 08:18:27 +00:00
cleanCacheTask->scheduleAfter(RESCHEDULE_MS);
2020-02-12 17:39:57 +00:00
}
2020-01-14 03:07:31 +00:00
void StorageWindowView::threadFuncToTable()
{
2020-01-24 02:45:45 +00:00
while (!shutdown_called && !target_table_id.empty())
2020-01-14 03:07:31 +00:00
{
2020-02-14 08:07:03 +00:00
std::unique_lock lock(flush_table_mutex);
condition.wait_for(lock, std::chrono::seconds(5));
2020-01-14 03:07:31 +00:00
try
{
2020-02-14 08:07:03 +00:00
while (!fire_signal.empty())
{
UInt32 timestamp_;
{
std::unique_lock lock_(fire_signal_mutex);
timestamp_ = fire_signal.front();
fire_signal.pop_front();
}
flushToTable(timestamp_);
}
2020-01-14 03:07:31 +00:00
}
catch (...)
{
tryLogCurrentException(__PRETTY_FUNCTION__);
break;
}
}
if (!shutdown_called)
toTableTask->scheduleAfter(RESCHEDULE_MS);
}
2020-02-14 08:07:03 +00:00
void StorageWindowView::threadFuncFire()
{
while (!shutdown_called)
{
UInt64 timestamp_usec = static_cast<UInt64>(Poco::Timestamp().epochMicroseconds());
UInt64 w_end = static_cast<UInt64>(getWindowUpperBound(static_cast<UInt32>(timestamp_usec / 1000000))) * 1000000;
std::this_thread::sleep_for(std::chrono::microseconds(w_end - timestamp_usec));
std::unique_lock lock(fire_signal_mutex);
addFireSignal(static_cast<UInt32>(w_end / 1000000));
}
if (!shutdown_called)
toTableTask->scheduleAfter(RESCHEDULE_MS);
}
2020-01-14 03:07:31 +00:00
BlockInputStreams StorageWindowView::watch(
const Names & /*column_names*/,
const SelectQueryInfo & query_info,
2020-02-12 17:39:57 +00:00
const Context & /*context*/,
2020-01-14 03:07:31 +00:00
QueryProcessingStage::Enum & processed_stage,
size_t /*max_block_size*/,
const unsigned /*num_streams*/)
{
ASTWatchQuery & query = typeid_cast<ASTWatchQuery &>(*query_info.query);
bool has_limit = false;
UInt64 limit = 0;
if (query.limit_length)
{
has_limit = true;
limit = safeGet<UInt64>(typeid_cast<ASTLiteral &>(*query.limit_length).value);
}
auto reader = std::make_shared<WindowViewBlockInputStream>(
std::static_pointer_cast<StorageWindowView>(shared_from_this()),
active_ptr,
has_limit,
2020-02-12 17:39:57 +00:00
limit);
2020-02-14 08:55:56 +00:00
2020-02-14 08:07:03 +00:00
{
std::lock_guard lock(fire_signal_mutex);
2020-02-20 17:30:58 +00:00
watch_streams.push_back(reader);
2020-02-14 08:07:03 +00:00
}
2020-01-14 03:07:31 +00:00
processed_stage = QueryProcessingStage::Complete;
return {reader};
}
Block StorageWindowView::getHeader() const
{
if (!sample_block)
{
2020-01-24 02:45:45 +00:00
auto storage = global_context.getTable(select_table_id);
sample_block = InterpreterSelectQuery(getInnerQuery(), global_context, storage, SelectQueryOptions(QueryProcessingStage::Complete))
2020-01-14 03:07:31 +00:00
.getSampleBlock();
for (size_t i = 0; i < sample_block.columns(); ++i)
sample_block.safeGetByPosition(i).column = sample_block.safeGetByPosition(i).column->convertToFullColumnIfConst();
}
return sample_block;
}
StorageWindowView::StorageWindowView(
2020-01-24 02:45:45 +00:00
const StorageID & table_id_,
2020-01-14 03:07:31 +00:00
Context & local_context,
const ASTCreateQuery & query,
2020-02-12 17:39:57 +00:00
const ColumnsDescription & columns_,
bool attach_)
2020-01-24 02:45:45 +00:00
: IStorage(table_id_)
2020-01-14 03:07:31 +00:00
, global_context(local_context.getGlobalContext())
, time_zone(DateLUT::instance())
{
setColumns(columns_);
if (!query.select)
throw Exception("SELECT query is not specified for " + getName(), ErrorCodes::INCORRECT_QUERY);
/// Default value, if only table name exist in the query
if (query.select->list_of_selects->children.size() != 1)
throw Exception("UNION is not supported for Window View", ErrorCodes::QUERY_IS_NOT_SUPPORTED_IN_WINDOW_VIEW);
auto inner_query_ = query.select->list_of_selects->children.at(0);
ASTSelectQuery & select_query = typeid_cast<ASTSelectQuery &>(*inner_query_);
2020-01-24 02:45:45 +00:00
String select_database_name = local_context.getCurrentDatabase();
String select_table_name;
2020-01-14 03:07:31 +00:00
extractDependentTable(select_query, select_database_name, select_table_name);
2020-01-24 02:45:45 +00:00
select_table_id = StorageID(select_database_name, select_table_name);
2020-01-14 03:07:31 +00:00
inner_query = innerQueryParser(select_query);
2020-02-17 05:06:03 +00:00
final_query = inner_query->clone();
ParserProcTimeFinalMatcher::Data final_query_data;
ParserProcTimeFinalMatcher::Visitor(final_query_data).visit(final_query);
is_proctime_tumble = final_query_data.is_proctime_tumble;
if (is_proctime_tumble)
window_column_name = final_query_data.window_column_name;
2020-01-14 03:07:31 +00:00
/// If the table is not specified - use the table `system.one`
if (select_table_name.empty())
{
select_database_name = "system";
select_table_name = "one";
}
2020-01-24 02:45:45 +00:00
global_context.addDependency(select_table_id, table_id_);
2020-01-14 03:07:31 +00:00
if (!query.to_table.empty())
2020-01-24 02:45:45 +00:00
target_table_id = StorageID(query.to_database, query.to_table);
2020-01-14 03:07:31 +00:00
2020-02-17 08:18:27 +00:00
clean_interval = local_context.getSettingsRef().window_view_clean_interval.totalSeconds();
2020-01-14 03:07:31 +00:00
mergeable_blocks = std::make_shared<std::list<BlocksListPtr>>();
active_ptr = std::make_shared<bool>(true);
2020-02-14 08:07:03 +00:00
if (query.watermark_function)
{
2020-02-17 05:06:03 +00:00
if (is_proctime_tumble)
throw Exception("WATERMARK is not support for Processing time processing.", ErrorCodes::INCORRECT_QUERY);
2020-02-14 08:07:03 +00:00
// parser watermark function
const auto & watermark_function = std::static_pointer_cast<ASTFunction>(query.watermark_function);
if (!startsWith(watermark_function->name, "toInterval"))
throw Exception(
"Illegal type WATERMARK function " + watermark_function->name + ", should be Interval", ErrorCodes::ILLEGAL_COLUMN);
String interval_str = watermark_function->name.substr(10);
const auto & interval_units_p1 = std::static_pointer_cast<ASTLiteral>(watermark_function->children.front()->children.front());
watermark_kind = strToIntervalKind(interval_str);
try
{
watermark_num_units = boost::lexical_cast<int>(interval_units_p1->value.get<String>());
}
2020-02-17 05:06:03 +00:00
catch (const boost::bad_lexical_cast &)
2020-02-14 08:07:03 +00:00
{
throw Exception("Cannot parse string '" + interval_units_p1->value.get<String>() + "' as Integer.", ErrorCodes::CANNOT_PARSE_TEXT);
}
2020-02-14 08:55:56 +00:00
if (watermark_num_units > 0)
2020-02-14 08:07:03 +00:00
watermark_num_units *= -1;
}
2020-02-12 17:39:57 +00:00
if (query.storage)
{
if (attach_)
{
inner_table_id = StorageID(table_id_.database_name, generateInnerTableName(table_id_.table_name));
}
else
{
2020-02-12 18:08:52 +00:00
if (query.storage->engine->name != "MergeTree")
2020-02-12 17:39:57 +00:00
throw Exception(
"The ENGINE of WindowView must be MergeTree family of table engines including the engines with replication support",
ErrorCodes::INCORRECT_QUERY);
auto manual_create_query
= generateInnerTableCreateQuery(query, table_id_.database_name, generateInnerTableName(table_id_.table_name));
InterpreterCreateQuery create_interpreter(manual_create_query, local_context);
create_interpreter.setInternal(true);
create_interpreter.execute();
inner_storage = global_context.getTable(manual_create_query->database, manual_create_query->table);
inner_table_id = inner_storage->getStorageID();
}
fetch_column_query = generateFetchColumnsQuery(inner_table_id);
}
2020-02-20 17:30:58 +00:00
{
// generate write expressions
ColumnsWithTypeAndName columns__;
columns__.emplace_back(
nullptr,
std::make_shared<DataTypeTuple>(DataTypes{std::make_shared<DataTypeDateTime>(), std::make_shared<DataTypeDateTime>()}),
window_column_name);
columns__.emplace_back(nullptr, std::make_shared<DataTypeDateTime>(), "____timestamp");
columns__.emplace_back(nullptr, std::make_shared<DataTypeDateTime>(), "____watermark");
const auto & function_tuple = FunctionFactory::instance().get("tupleElement", global_context);
writeExpressions = std::make_shared<ExpressionActions>(columns__, global_context);
writeExpressions->add(ExpressionAction::addColumn(
{std::make_shared<DataTypeUInt8>()->createColumnConst(1, toField(2)), std::make_shared<DataTypeUInt8>(), "____tuple_arg"}));
writeExpressions->add(ExpressionAction::applyFunction(function_tuple, Names{window_column_name, "____tuple_arg"}, "____w_end"));
writeExpressions->add(ExpressionAction::removeColumn("____tuple_arg"));
const auto & function_greater = FunctionFactory::instance().get("greaterOrEquals", global_context);
writeExpressions->add(ExpressionAction::applyFunction(function_greater, Names{"____w_end", "____watermark"}, "____filter"));
writeExpressions->add(ExpressionAction::removeColumn("____watermark"));
}
2020-01-24 02:45:45 +00:00
toTableTask = global_context.getSchedulePool().createTask(getStorageID().getFullTableName(), [this] { threadFuncToTable(); });
2020-02-17 08:18:27 +00:00
cleanCacheTask = global_context.getSchedulePool().createTask(getStorageID().getFullTableName(), [this] { threadFuncCleanCache(); });
2020-02-14 08:07:03 +00:00
fireTask = global_context.getSchedulePool().createTask(getStorageID().getFullTableName(), [this] { threadFuncFire(); });
2020-01-14 03:07:31 +00:00
toTableTask->deactivate();
2020-02-17 08:18:27 +00:00
cleanCacheTask->deactivate();
2020-02-14 08:07:03 +00:00
fireTask->deactivate();
2020-01-14 03:07:31 +00:00
}
ASTPtr StorageWindowView::innerQueryParser(ASTSelectQuery & query)
{
if (!query.groupBy())
throw Exception("GROUP BY query is required for " + getName(), ErrorCodes::INCORRECT_QUERY);
// parse stage mergeable
ASTPtr result = query.clone();
ASTPtr expr_list = result;
ParserStageMergeableOneMatcher::Data stageMergeableOneData;
ParserStageMergeableOneMatcher::Visitor(stageMergeableOneData).visit(expr_list);
if (!stageMergeableOneData.is_tumble && !stageMergeableOneData.is_hop)
throw Exception("WINDOW FUNCTION is not specified for " + getName(), ErrorCodes::INCORRECT_QUERY);
window_column_name = stageMergeableOneData.window_column_name;
// parser window function
ASTFunction & window_function = typeid_cast<ASTFunction &>(*stageMergeableOneData.window_function);
2020-02-12 17:39:57 +00:00
const auto & arguments = window_function.arguments->children;
2020-02-14 08:07:03 +00:00
const auto & arg1 = std::static_pointer_cast<ASTFunction>(arguments.at(1));
if (!arg1 || !startsWith(arg1->name, "toInterval"))
throw Exception("Illegal type of last argument of function " + arg1->name + " should be Interval", ErrorCodes::ILLEGAL_COLUMN);
String interval_str = arg1->name.substr(10);
window_kind = strToIntervalKind(interval_str);
const auto & interval_units_p1 = std::static_pointer_cast<ASTLiteral>(arg1->children.front()->children.front());
2020-01-14 03:07:31 +00:00
window_num_units = stoi(interval_units_p1->value.get<String>());
return result;
}
void StorageWindowView::writeIntoWindowView(StorageWindowView & window_view, const Block & block, const Context & context)
{
2020-02-14 08:07:03 +00:00
UInt32 timestamp_now = std::time(nullptr);
2020-02-20 17:30:58 +00:00
UInt32 watermark;
2020-02-17 05:06:03 +00:00
auto block_stream = std::make_shared<OneBlockInputStream>(block);
2020-02-20 17:30:58 +00:00
BlockInputStreamPtr source_stream;
2020-02-17 05:06:03 +00:00
if (window_view.is_proctime_tumble)
2020-02-20 17:30:58 +00:00
{
source_stream = std::make_shared<AddingConstColumnBlockInputStream<UInt32>>(block_stream, std::make_shared<DataTypeDateTime>(), timestamp_now, "____timestamp");
watermark = window_view.getWindowLowerBound(timestamp_now);
}
2020-02-17 05:06:03 +00:00
else
2020-02-20 17:30:58 +00:00
{
source_stream = block_stream;
watermark = window_view.getWatermark(timestamp_now);
}
2020-02-14 08:07:03 +00:00
2020-01-14 03:07:31 +00:00
InterpreterSelectQuery select_block(
2020-02-20 17:30:58 +00:00
window_view.getFinalQuery(), context, source_stream, QueryProcessingStage::WithMergeableState);
source_stream = std::make_shared<MaterializingBlockInputStream>(select_block.execute().in);
source_stream = std::make_shared<AddingConstColumnBlockInputStream<UInt32>>(source_stream, std::make_shared<DataTypeDateTime>(), watermark, "____watermark");
2020-02-14 08:07:03 +00:00
BlockInputStreamPtr in_stream;
2020-02-20 17:30:58 +00:00
in_stream = std::make_shared<FilterBlockInputStream>(source_stream, window_view.writeExpressions, "____filter", true);
2020-02-12 17:39:57 +00:00
2020-02-14 08:07:03 +00:00
if (!window_view.inner_table_id.empty())
2020-01-14 03:07:31 +00:00
{
2020-02-12 17:39:57 +00:00
auto stream = window_view.getInnerStorage()->write(window_view.getInnerQuery(), context);
2020-02-17 05:06:03 +00:00
if (window_view.is_proctime_tumble)
{
std::unique_lock lock(window_view.fire_signal_mutex);
copyData(*in_stream, *stream);
}
else if (window_view.watermark_num_units != 0)
2020-02-12 17:39:57 +00:00
{
2020-02-14 08:07:03 +00:00
while (Block block_ = in_stream->read())
{
2020-02-17 05:06:03 +00:00
auto column_wend = block_.getByName("____w_end").column;
2020-02-14 08:07:03 +00:00
stream->write(std::move(block_));
const ColumnUInt32::Container & wend_data
2020-02-17 05:06:03 +00:00
= static_cast<const ColumnUInt32 &>(*column_wend).getData();
2020-02-17 15:03:39 +00:00
std::unique_lock lock(window_view.fire_signal_mutex);
2020-02-14 08:07:03 +00:00
for (size_t i = 0; i < wend_data.size(); ++i)
{
if (wend_data[i] < timestamp_now)
window_view.addFireSignal(wend_data[i]);
}
}
2020-02-12 17:39:57 +00:00
}
2020-02-14 08:07:03 +00:00
else
copyData(*in_stream, *stream);
2020-01-14 03:07:31 +00:00
}
2020-02-12 17:39:57 +00:00
else
2020-01-14 03:07:31 +00:00
{
2020-02-12 17:39:57 +00:00
BlocksListPtr new_mergeable_blocks = std::make_shared<BlocksList>();
2020-02-17 05:06:03 +00:00
if (window_view.is_proctime_tumble)
{
std::unique_lock lock(window_view.fire_signal_mutex);
while (Block block_ = in_stream->read())
new_mergeable_blocks->push_back(std::move(block_));
}
2020-02-14 08:55:56 +00:00
if (window_view.watermark_num_units != 0)
2020-02-14 08:07:03 +00:00
{
while (Block block_ = in_stream->read())
{
2020-02-17 05:06:03 +00:00
auto column_wend = block_.getByName("____w_end").column;
2020-02-14 08:07:03 +00:00
new_mergeable_blocks->push_back(std::move(block_));
const ColumnUInt32::Container & wend_data
2020-02-17 05:06:03 +00:00
= static_cast<const ColumnUInt32 &>(*column_wend).getData();
2020-02-17 15:03:39 +00:00
std::unique_lock lock(window_view.fire_signal_mutex);
2020-02-14 08:07:03 +00:00
for (size_t i = 0; i < wend_data.size(); ++i)
{
if (wend_data[i] < timestamp_now)
window_view.addFireSignal(wend_data[i]);
}
}
}
else
2020-02-12 17:39:57 +00:00
{
2020-02-14 08:07:03 +00:00
while (Block block_ = in_stream->read())
new_mergeable_blocks->push_back(std::move(block_));
2020-02-12 17:39:57 +00:00
}
2020-02-20 17:30:58 +00:00
std::unique_lock lock(window_view.mutex);
window_view.getMergeableBlocksList()->push_back(new_mergeable_blocks);
2020-01-14 03:07:31 +00:00
}
}
void StorageWindowView::startup()
{
// Start the working thread
2020-01-24 02:45:45 +00:00
if (!target_table_id.empty())
2020-01-14 03:07:31 +00:00
toTableTask->activateAndSchedule();
2020-02-20 17:30:58 +00:00
cleanCacheTask->activateAndSchedule();
2020-02-14 08:07:03 +00:00
fireTask->activateAndSchedule();
2020-01-14 03:07:31 +00:00
}
void StorageWindowView::shutdown()
{
bool expected = false;
if (!shutdown_called.compare_exchange_strong(expected, true))
return;
toTableTask->deactivate();
2020-02-17 08:18:27 +00:00
cleanCacheTask->deactivate();
2020-02-14 08:07:03 +00:00
fireTask->deactivate();
2020-01-14 03:07:31 +00:00
}
StorageWindowView::~StorageWindowView()
{
shutdown();
}
2020-02-14 08:07:03 +00:00
BlockInputStreamPtr StorageWindowView::getNewBlocksInputStreamPtr(UInt32 timestamp_)
2020-01-14 03:07:31 +00:00
{
2020-02-17 05:06:03 +00:00
BlockInputStreamPtr stream;
2020-01-14 03:07:31 +00:00
2020-02-17 05:06:03 +00:00
if (!inner_table_id.empty())
{
auto & storage = getInnerStorage();
InterpreterSelectQuery fetch(fetch_column_query, global_context, storage, SelectQueryOptions(QueryProcessingStage::FetchColumns));
ColumnsWithTypeAndName columns_;
columns_.emplace_back(nullptr, std::make_shared<DataTypeDateTime>(), "____w_end");
ExpressionActionsPtr actions_ = std::make_shared<ExpressionActions>(columns_, global_context);
actions_->add(ExpressionAction::addColumn({std::make_shared<DataTypeDateTime>()->createColumnConst(1, toField(timestamp_)),
std::make_shared<DataTypeDateTime>(),
"____timestamp_now"}));
const auto & function_equals = FunctionFactory::instance().get("equals", global_context);
ExpressionActionsPtr apply_function_actions = std::make_shared<ExpressionActions>(columns_, global_context);
actions_->add(ExpressionAction::applyFunction(function_equals, Names{"____w_end", "____timestamp_now"}, "____filter"));
actions_->add(ExpressionAction::removeColumn("____w_end"));
actions_->add(ExpressionAction::removeColumn("____timestamp_now"));
stream = std::make_shared<FilterBlockInputStream>(fetch.execute().in, actions_, "____filter", true);
}
else
{
if (mergeable_blocks->empty())
return std::make_shared<NullBlockInputStream>(getHeader());
auto sample_block_ = mergeable_blocks->front()->front().cloneEmpty();
stream = std::make_shared<BlocksListInputStream>(mergeable_blocks, sample_block_, timestamp_);
}
2020-01-14 03:07:31 +00:00
2020-02-12 17:39:57 +00:00
BlockInputStreams from;
from.push_back(std::move(stream));
auto proxy_storage = std::make_shared<WindowViewProxyStorage>(
StorageID("", "WindowViewProxyStorage"), getParentStorage(), std::move(from), QueryProcessingStage::WithMergeableState);
2020-01-14 03:07:31 +00:00
2020-02-17 05:06:03 +00:00
InterpreterSelectQuery select(getFinalQuery(), global_context, proxy_storage, QueryProcessingStage::Complete);
2020-02-12 17:39:57 +00:00
BlockInputStreamPtr data = std::make_shared<MaterializingBlockInputStream>(select.execute().in);
return data;
2020-01-14 03:07:31 +00:00
}
void registerStorageWindowView(StorageFactory & factory)
{
2020-01-14 09:53:52 +00:00
factory.registerStorage("WindowView", [](const StorageFactory::Arguments & args)
{
2020-01-14 03:07:31 +00:00
if (!args.attach && !args.local_context.getSettingsRef().allow_experimental_window_view)
throw Exception(
"Experimental WINDOW VIEW feature is not enabled (the setting 'allow_experimental_window_view')",
ErrorCodes::SUPPORT_IS_DISABLED);
2020-01-24 02:45:45 +00:00
2020-02-12 17:39:57 +00:00
return StorageWindowView::create(args.table_id, args.local_context, args.query, args.columns, args.attach);
2020-01-14 03:07:31 +00:00
});
}
2020-02-12 17:39:57 +00:00
2020-01-14 16:24:26 +00:00
}