mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-10 09:32:06 +00:00
Refactor ArrayJoin step.
This commit is contained in:
parent
2d3e5a37e9
commit
7339ff156e
@ -27,7 +27,8 @@ class FunctionStringOrArrayToT : public IFunction
|
|||||||
{
|
{
|
||||||
public:
|
public:
|
||||||
static constexpr auto name = Name::name;
|
static constexpr auto name = Name::name;
|
||||||
static FunctionPtr create(ContextPtr)
|
static FunctionPtr create(ContextPtr) { return createImpl(); }
|
||||||
|
static FunctionPtr createImpl()
|
||||||
{
|
{
|
||||||
return std::make_shared<FunctionStringOrArrayToT>();
|
return std::make_shared<FunctionStringOrArrayToT>();
|
||||||
}
|
}
|
||||||
|
@ -1,4 +1,4 @@
|
|||||||
#include <Functions/IFunction.h>
|
#include <Functions/array/arrayResize.h>
|
||||||
#include <Functions/FunctionFactory.h>
|
#include <Functions/FunctionFactory.h>
|
||||||
#include <Functions/GatherUtils/GatherUtils.h>
|
#include <Functions/GatherUtils/GatherUtils.h>
|
||||||
#include <DataTypes/DataTypeArray.h>
|
#include <DataTypes/DataTypeArray.h>
|
||||||
@ -21,117 +21,99 @@ namespace ErrorCodes
|
|||||||
extern const int ILLEGAL_TYPE_OF_ARGUMENT;
|
extern const int ILLEGAL_TYPE_OF_ARGUMENT;
|
||||||
}
|
}
|
||||||
|
|
||||||
class FunctionArrayResize : public IFunction
|
DataTypePtr FunctionArrayResize::getReturnTypeImpl(const DataTypes & arguments) const
|
||||||
{
|
{
|
||||||
public:
|
const size_t number_of_arguments = arguments.size();
|
||||||
static constexpr auto name = "arrayResize";
|
|
||||||
static FunctionPtr create(ContextPtr) { return std::make_shared<FunctionArrayResize>(); }
|
|
||||||
|
|
||||||
String getName() const override { return name; }
|
if (number_of_arguments < 2 || number_of_arguments > 3)
|
||||||
|
throw Exception(ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH,
|
||||||
|
"Number of arguments for function {} doesn't match: passed {}, should be 2 or 3",
|
||||||
|
getName(), number_of_arguments);
|
||||||
|
|
||||||
bool isVariadic() const override { return true; }
|
if (arguments[0]->onlyNull())
|
||||||
size_t getNumberOfArguments() const override { return 0; }
|
return arguments[0];
|
||||||
|
|
||||||
bool isSuitableForShortCircuitArgumentsExecution(const DataTypesWithConstInfo & /*arguments*/) const override { return true; }
|
const auto * array_type = typeid_cast<const DataTypeArray *>(arguments[0].get());
|
||||||
|
if (!array_type)
|
||||||
|
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT,
|
||||||
|
"First argument for function {} must be an array but it has type {}.",
|
||||||
|
getName(), arguments[0]->getName());
|
||||||
|
|
||||||
DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override
|
if (WhichDataType(array_type->getNestedType()).isNothing())
|
||||||
|
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT, "Function {} cannot resize {}", getName(), array_type->getName());
|
||||||
|
|
||||||
|
if (!isInteger(removeNullable(arguments[1])) && !arguments[1]->onlyNull())
|
||||||
|
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT,
|
||||||
|
"Argument {} for function {} must be integer but it has type {}.",
|
||||||
|
toString(1), getName(), arguments[1]->getName());
|
||||||
|
|
||||||
|
if (number_of_arguments == 2)
|
||||||
|
return arguments[0];
|
||||||
|
else /* if (number_of_arguments == 3) */
|
||||||
|
return std::make_shared<DataTypeArray>(getLeastSupertype(DataTypes{array_type->getNestedType(), arguments[2]}));
|
||||||
|
}
|
||||||
|
|
||||||
|
ColumnPtr FunctionArrayResize::executeImpl(const ColumnsWithTypeAndName & arguments, const DataTypePtr & return_type, size_t input_rows_count) const
|
||||||
|
{
|
||||||
|
if (return_type->onlyNull())
|
||||||
|
return return_type->createColumnConstWithDefaultValue(input_rows_count);
|
||||||
|
|
||||||
|
auto result_column = return_type->createColumn();
|
||||||
|
|
||||||
|
auto array_column = arguments[0].column;
|
||||||
|
auto size_column = arguments[1].column;
|
||||||
|
|
||||||
|
if (!arguments[0].type->equals(*return_type))
|
||||||
|
array_column = castColumn(arguments[0], return_type);
|
||||||
|
|
||||||
|
const DataTypePtr & return_nested_type = typeid_cast<const DataTypeArray &>(*return_type).getNestedType();
|
||||||
|
size_t size = array_column->size();
|
||||||
|
|
||||||
|
ColumnPtr appended_column;
|
||||||
|
if (arguments.size() == 3)
|
||||||
{
|
{
|
||||||
const size_t number_of_arguments = arguments.size();
|
appended_column = arguments[2].column;
|
||||||
|
if (!arguments[2].type->equals(*return_nested_type))
|
||||||
|
appended_column = castColumn(arguments[2], return_nested_type);
|
||||||
|
}
|
||||||
|
else
|
||||||
|
appended_column = return_nested_type->createColumnConstWithDefaultValue(size);
|
||||||
|
|
||||||
if (number_of_arguments < 2 || number_of_arguments > 3)
|
std::unique_ptr<GatherUtils::IArraySource> array_source;
|
||||||
throw Exception(ErrorCodes::NUMBER_OF_ARGUMENTS_DOESNT_MATCH,
|
std::unique_ptr<GatherUtils::IValueSource> value_source;
|
||||||
"Number of arguments for function {} doesn't match: passed {}, should be 2 or 3",
|
|
||||||
getName(), number_of_arguments);
|
|
||||||
|
|
||||||
if (arguments[0]->onlyNull())
|
bool is_const = false;
|
||||||
return arguments[0];
|
|
||||||
|
|
||||||
const auto * array_type = typeid_cast<const DataTypeArray *>(arguments[0].get());
|
if (const auto * const_array_column = typeid_cast<const ColumnConst *>(array_column.get()))
|
||||||
if (!array_type)
|
{
|
||||||
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT,
|
is_const = true;
|
||||||
"First argument for function {} must be an array but it has type {}.",
|
array_column = const_array_column->getDataColumnPtr();
|
||||||
getName(), arguments[0]->getName());
|
|
||||||
|
|
||||||
if (WhichDataType(array_type->getNestedType()).isNothing())
|
|
||||||
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT, "Function {} cannot resize {}", getName(), array_type->getName());
|
|
||||||
|
|
||||||
if (!isInteger(removeNullable(arguments[1])) && !arguments[1]->onlyNull())
|
|
||||||
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT,
|
|
||||||
"Argument {} for function {} must be integer but it has type {}.",
|
|
||||||
toString(1), getName(), arguments[1]->getName());
|
|
||||||
|
|
||||||
if (number_of_arguments == 2)
|
|
||||||
return arguments[0];
|
|
||||||
else /* if (number_of_arguments == 3) */
|
|
||||||
return std::make_shared<DataTypeArray>(getLeastSupertype(DataTypes{array_type->getNestedType(), arguments[2]}));
|
|
||||||
}
|
}
|
||||||
|
|
||||||
ColumnPtr executeImpl(const ColumnsWithTypeAndName & arguments, const DataTypePtr & return_type, size_t input_rows_count) const override
|
if (const auto * argument_column_array = typeid_cast<const ColumnArray *>(array_column.get()))
|
||||||
|
array_source = GatherUtils::createArraySource(*argument_column_array, is_const, size);
|
||||||
|
else
|
||||||
|
throw Exception(ErrorCodes::LOGICAL_ERROR, "First arguments for function {} must be array.", getName());
|
||||||
|
|
||||||
|
|
||||||
|
bool is_appended_const = false;
|
||||||
|
if (const auto * const_appended_column = typeid_cast<const ColumnConst *>(appended_column.get()))
|
||||||
{
|
{
|
||||||
if (return_type->onlyNull())
|
is_appended_const = true;
|
||||||
return return_type->createColumnConstWithDefaultValue(input_rows_count);
|
appended_column = const_appended_column->getDataColumnPtr();
|
||||||
|
|
||||||
auto result_column = return_type->createColumn();
|
|
||||||
|
|
||||||
auto array_column = arguments[0].column;
|
|
||||||
auto size_column = arguments[1].column;
|
|
||||||
|
|
||||||
if (!arguments[0].type->equals(*return_type))
|
|
||||||
array_column = castColumn(arguments[0], return_type);
|
|
||||||
|
|
||||||
const DataTypePtr & return_nested_type = typeid_cast<const DataTypeArray &>(*return_type).getNestedType();
|
|
||||||
size_t size = array_column->size();
|
|
||||||
|
|
||||||
ColumnPtr appended_column;
|
|
||||||
if (arguments.size() == 3)
|
|
||||||
{
|
|
||||||
appended_column = arguments[2].column;
|
|
||||||
if (!arguments[2].type->equals(*return_nested_type))
|
|
||||||
appended_column = castColumn(arguments[2], return_nested_type);
|
|
||||||
}
|
|
||||||
else
|
|
||||||
appended_column = return_nested_type->createColumnConstWithDefaultValue(size);
|
|
||||||
|
|
||||||
std::unique_ptr<GatherUtils::IArraySource> array_source;
|
|
||||||
std::unique_ptr<GatherUtils::IValueSource> value_source;
|
|
||||||
|
|
||||||
bool is_const = false;
|
|
||||||
|
|
||||||
if (const auto * const_array_column = typeid_cast<const ColumnConst *>(array_column.get()))
|
|
||||||
{
|
|
||||||
is_const = true;
|
|
||||||
array_column = const_array_column->getDataColumnPtr();
|
|
||||||
}
|
|
||||||
|
|
||||||
if (const auto * argument_column_array = typeid_cast<const ColumnArray *>(array_column.get()))
|
|
||||||
array_source = GatherUtils::createArraySource(*argument_column_array, is_const, size);
|
|
||||||
else
|
|
||||||
throw Exception(ErrorCodes::LOGICAL_ERROR, "First arguments for function {} must be array.", getName());
|
|
||||||
|
|
||||||
|
|
||||||
bool is_appended_const = false;
|
|
||||||
if (const auto * const_appended_column = typeid_cast<const ColumnConst *>(appended_column.get()))
|
|
||||||
{
|
|
||||||
is_appended_const = true;
|
|
||||||
appended_column = const_appended_column->getDataColumnPtr();
|
|
||||||
}
|
|
||||||
|
|
||||||
value_source = GatherUtils::createValueSource(*appended_column, is_appended_const, size);
|
|
||||||
|
|
||||||
auto sink = GatherUtils::createArraySink(typeid_cast<ColumnArray &>(*result_column), size);
|
|
||||||
|
|
||||||
if (isColumnConst(*size_column))
|
|
||||||
GatherUtils::resizeConstantSize(*array_source, *value_source, *sink, size_column->getInt(0));
|
|
||||||
else
|
|
||||||
GatherUtils::resizeDynamicSize(*array_source, *value_source, *sink, *size_column);
|
|
||||||
|
|
||||||
return result_column;
|
|
||||||
}
|
}
|
||||||
|
|
||||||
bool useDefaultImplementationForConstants() const override { return true; }
|
value_source = GatherUtils::createValueSource(*appended_column, is_appended_const, size);
|
||||||
bool useDefaultImplementationForNulls() const override { return false; }
|
|
||||||
};
|
|
||||||
|
|
||||||
|
auto sink = GatherUtils::createArraySink(typeid_cast<ColumnArray &>(*result_column), size);
|
||||||
|
|
||||||
|
if (isColumnConst(*size_column))
|
||||||
|
GatherUtils::resizeConstantSize(*array_source, *value_source, *sink, size_column->getInt(0));
|
||||||
|
else
|
||||||
|
GatherUtils::resizeDynamicSize(*array_source, *value_source, *sink, *size_column);
|
||||||
|
|
||||||
|
return result_column;
|
||||||
|
}
|
||||||
|
|
||||||
REGISTER_FUNCTION(ArrayResize)
|
REGISTER_FUNCTION(ArrayResize)
|
||||||
{
|
{
|
||||||
|
@ -1,4 +1,4 @@
|
|||||||
#include <Functions/IFunction.h>
|
#include <Functions/array/emptyArrayToSingle.h>
|
||||||
#include <Functions/FunctionFactory.h>
|
#include <Functions/FunctionFactory.h>
|
||||||
#include <Functions/FunctionHelpers.h>
|
#include <Functions/FunctionHelpers.h>
|
||||||
#include <DataTypes/DataTypeArray.h>
|
#include <DataTypes/DataTypeArray.h>
|
||||||
@ -20,35 +20,6 @@ namespace ErrorCodes
|
|||||||
extern const int ILLEGAL_TYPE_OF_ARGUMENT;
|
extern const int ILLEGAL_TYPE_OF_ARGUMENT;
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
||||||
/** emptyArrayToSingle(arr) - replace empty arrays with arrays of one element with a default value.
|
|
||||||
*/
|
|
||||||
class FunctionEmptyArrayToSingle : public IFunction
|
|
||||||
{
|
|
||||||
public:
|
|
||||||
static constexpr auto name = "emptyArrayToSingle";
|
|
||||||
static FunctionPtr create(ContextPtr) { return std::make_shared<FunctionEmptyArrayToSingle>(); }
|
|
||||||
|
|
||||||
String getName() const override { return name; }
|
|
||||||
|
|
||||||
size_t getNumberOfArguments() const override { return 1; }
|
|
||||||
bool useDefaultImplementationForConstants() const override { return true; }
|
|
||||||
bool useDefaultImplementationForLowCardinalityColumns() const override { return false; }
|
|
||||||
bool isSuitableForShortCircuitArgumentsExecution(const DataTypesWithConstInfo & /*arguments*/) const override { return false; }
|
|
||||||
|
|
||||||
DataTypePtr getReturnTypeImpl(const DataTypes & arguments) const override
|
|
||||||
{
|
|
||||||
const DataTypeArray * array_type = checkAndGetDataType<DataTypeArray>(arguments[0].get());
|
|
||||||
if (!array_type)
|
|
||||||
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT, "Argument for function {} must be array.", getName());
|
|
||||||
|
|
||||||
return arguments[0];
|
|
||||||
}
|
|
||||||
|
|
||||||
ColumnPtr executeImpl(const ColumnsWithTypeAndName & arguments, const DataTypePtr & result_type, size_t input_rows_count) const override;
|
|
||||||
};
|
|
||||||
|
|
||||||
|
|
||||||
namespace
|
namespace
|
||||||
{
|
{
|
||||||
namespace FunctionEmptyArrayToSingleImpl
|
namespace FunctionEmptyArrayToSingleImpl
|
||||||
@ -366,6 +337,14 @@ namespace
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
DataTypePtr FunctionEmptyArrayToSingle::getReturnTypeImpl(const DataTypes & arguments) const
|
||||||
|
{
|
||||||
|
const DataTypeArray * array_type = checkAndGetDataType<DataTypeArray>(arguments[0].get());
|
||||||
|
if (!array_type)
|
||||||
|
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT, "Argument for function {} must be array.", getName());
|
||||||
|
|
||||||
|
return arguments[0];
|
||||||
|
}
|
||||||
|
|
||||||
ColumnPtr FunctionEmptyArrayToSingle::executeImpl(const ColumnsWithTypeAndName & arguments, const DataTypePtr & result_type, size_t input_rows_count) const
|
ColumnPtr FunctionEmptyArrayToSingle::executeImpl(const ColumnsWithTypeAndName & arguments, const DataTypePtr & result_type, size_t input_rows_count) const
|
||||||
{
|
{
|
||||||
|
@ -1,65 +1,7 @@
|
|||||||
#include <DataTypes/DataTypeString.h>
|
#include <Functions/array/length.h>
|
||||||
#include <Functions/FunctionFactory.h>
|
|
||||||
#include <Functions/FunctionStringOrArrayToT.h>
|
|
||||||
|
|
||||||
|
|
||||||
namespace DB
|
namespace DB
|
||||||
{
|
{
|
||||||
namespace ErrorCodes
|
|
||||||
{
|
|
||||||
extern const int ILLEGAL_TYPE_OF_ARGUMENT;
|
|
||||||
}
|
|
||||||
|
|
||||||
/** Calculates the length of a string in bytes.
|
|
||||||
*/
|
|
||||||
struct LengthImpl
|
|
||||||
{
|
|
||||||
static constexpr auto is_fixed_to_constant = true;
|
|
||||||
|
|
||||||
static void vector(const ColumnString::Chars & /*data*/, const ColumnString::Offsets & offsets, PaddedPODArray<UInt64> & res, size_t input_rows_count)
|
|
||||||
{
|
|
||||||
for (size_t i = 0; i < input_rows_count; ++i)
|
|
||||||
res[i] = offsets[i] - 1 - offsets[i - 1];
|
|
||||||
}
|
|
||||||
|
|
||||||
static void vectorFixedToConstant(const ColumnString::Chars & /*data*/, size_t n, UInt64 & res, size_t)
|
|
||||||
{
|
|
||||||
res = n;
|
|
||||||
}
|
|
||||||
|
|
||||||
static void vectorFixedToVector(const ColumnString::Chars & /*data*/, size_t /*n*/, PaddedPODArray<UInt64> & /*res*/, size_t)
|
|
||||||
{
|
|
||||||
}
|
|
||||||
|
|
||||||
static void array(const ColumnString::Offsets & offsets, PaddedPODArray<UInt64> & res, size_t input_rows_count)
|
|
||||||
{
|
|
||||||
for (size_t i = 0; i < input_rows_count; ++i)
|
|
||||||
res[i] = offsets[i] - offsets[i - 1];
|
|
||||||
}
|
|
||||||
|
|
||||||
[[noreturn]] static void uuid(const ColumnUUID::Container &, size_t &, PaddedPODArray<UInt64> &, size_t)
|
|
||||||
{
|
|
||||||
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT, "Cannot apply function length to UUID argument");
|
|
||||||
}
|
|
||||||
|
|
||||||
[[noreturn]] static void ipv6(const ColumnIPv6::Container &, size_t &, PaddedPODArray<UInt64> &, size_t)
|
|
||||||
{
|
|
||||||
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT, "Cannot apply function length to IPv6 argument");
|
|
||||||
}
|
|
||||||
|
|
||||||
[[noreturn]] static void ipv4(const ColumnIPv4::Container &, size_t &, PaddedPODArray<UInt64> &, size_t)
|
|
||||||
{
|
|
||||||
throw Exception(ErrorCodes::ILLEGAL_TYPE_OF_ARGUMENT, "Cannot apply function length to IPv4 argument");
|
|
||||||
}
|
|
||||||
};
|
|
||||||
|
|
||||||
|
|
||||||
struct NameLength
|
|
||||||
{
|
|
||||||
static constexpr auto name = "length";
|
|
||||||
};
|
|
||||||
|
|
||||||
using FunctionLength = FunctionStringOrArrayToT<LengthImpl, NameLength, UInt64, false>;
|
|
||||||
|
|
||||||
REGISTER_FUNCTION(Length)
|
REGISTER_FUNCTION(Length)
|
||||||
{
|
{
|
||||||
|
@ -6,6 +6,9 @@
|
|||||||
#include <Columns/ColumnMap.h>
|
#include <Columns/ColumnMap.h>
|
||||||
#include <DataTypes/DataTypesNumber.h>
|
#include <DataTypes/DataTypesNumber.h>
|
||||||
#include <Functions/FunctionFactory.h>
|
#include <Functions/FunctionFactory.h>
|
||||||
|
#include <Functions/array/length.h>
|
||||||
|
#include <Functions/array/arrayResize.h>
|
||||||
|
#include <Functions/array/emptyArrayToSingle.h>
|
||||||
#include <Interpreters/Context.h>
|
#include <Interpreters/Context.h>
|
||||||
#include <Interpreters/ArrayJoinAction.h>
|
#include <Interpreters/ArrayJoinAction.h>
|
||||||
|
|
||||||
@ -59,26 +62,27 @@ ColumnWithTypeAndName convertArrayJoinColumn(const ColumnWithTypeAndName & src_c
|
|||||||
return array_col;
|
return array_col;
|
||||||
}
|
}
|
||||||
|
|
||||||
ArrayJoinAction::ArrayJoinAction(const NameSet & array_joined_columns_, bool array_join_is_left, ContextPtr context)
|
ArrayJoinAction::ArrayJoinAction(const NameSet & array_joined_columns_, bool is_left_, bool is_unaligned_, size_t max_block_size_)
|
||||||
: columns(array_joined_columns_)
|
: columns(array_joined_columns_)
|
||||||
, is_left(array_join_is_left)
|
, is_left(is_left_)
|
||||||
, is_unaligned(context->getSettingsRef().enable_unaligned_array_join)
|
, is_unaligned(is_unaligned_)
|
||||||
, max_block_size(context->getSettingsRef().max_block_size)
|
, max_block_size(max_block_size_)
|
||||||
|
// , is_unaligned(context->getSettingsRef().enable_unaligned_array_join)
|
||||||
|
// , max_block_size(context->getSettingsRef().max_block_size)
|
||||||
{
|
{
|
||||||
if (columns.empty())
|
if (columns.empty())
|
||||||
throw Exception(ErrorCodes::LOGICAL_ERROR, "No arrays to join");
|
throw Exception(ErrorCodes::LOGICAL_ERROR, "No arrays to join");
|
||||||
|
|
||||||
if (is_unaligned)
|
if (is_unaligned)
|
||||||
{
|
{
|
||||||
function_length = FunctionFactory::instance().get("length", context);
|
function_length = std::make_unique<FunctionToOverloadResolverAdaptor>(FunctionLength::createImpl());
|
||||||
function_greatest = FunctionFactory::instance().get("greatest", context);
|
function_array_resize = std::make_unique<FunctionToOverloadResolverAdaptor>(FunctionArrayResize::createImpl());
|
||||||
function_array_resize = FunctionFactory::instance().get("arrayResize", context);
|
|
||||||
}
|
}
|
||||||
else if (is_left)
|
else if (is_left)
|
||||||
function_builder = FunctionFactory::instance().get("emptyArrayToSingle", context);
|
function_builder = std::make_unique<FunctionToOverloadResolverAdaptor>(FunctionEmptyArrayToSingle::createImpl());
|
||||||
}
|
}
|
||||||
|
|
||||||
void ArrayJoinAction::prepare(ColumnsWithTypeAndName & sample) const
|
void ArrayJoinAction::prepare(const NameSet & columns, ColumnsWithTypeAndName & sample)
|
||||||
{
|
{
|
||||||
for (auto & current : sample)
|
for (auto & current : sample)
|
||||||
{
|
{
|
||||||
@ -103,6 +107,35 @@ ArrayJoinResultIteratorPtr ArrayJoinAction::execute(Block block)
|
|||||||
return std::make_unique<ArrayJoinResultIterator>(this, std::move(block));
|
return std::make_unique<ArrayJoinResultIterator>(this, std::move(block));
|
||||||
}
|
}
|
||||||
|
|
||||||
|
static void updateMaxLength(ColumnUInt64 & max_length, UInt64 length)
|
||||||
|
{
|
||||||
|
for (auto & value : max_length.getData())
|
||||||
|
value = std::max(value, length);
|
||||||
|
}
|
||||||
|
|
||||||
|
static void updateMaxLength(ColumnUInt64 & max_length, const IColumn & length)
|
||||||
|
{
|
||||||
|
if (const auto * length_const = typeid_cast<const ColumnConst *>(&length))
|
||||||
|
{
|
||||||
|
updateMaxLength(max_length, length_const->getUInt(0));
|
||||||
|
return;
|
||||||
|
}
|
||||||
|
|
||||||
|
const auto * length_uint64 = typeid_cast<const ColumnUInt64 *>(&length);
|
||||||
|
if (!length_uint64)
|
||||||
|
throw Exception(ErrorCodes::LOGICAL_ERROR, "Expected UInt64 for array length, got {}", length.getName());
|
||||||
|
|
||||||
|
auto & max_lenght_data = max_length.getData();
|
||||||
|
const auto & length_data = length_uint64->getData();
|
||||||
|
size_t num_rows = max_lenght_data.size();
|
||||||
|
if (num_rows != length_data.size())
|
||||||
|
throw Exception(
|
||||||
|
ErrorCodes::LOGICAL_ERROR,
|
||||||
|
"Different columns sizes in ARRAY JOIN: {} and {}", num_rows, length_data.size());
|
||||||
|
|
||||||
|
for (size_t row = 0; row < num_rows; ++row)
|
||||||
|
max_lenght_data[row] = std::max(max_lenght_data[row], length_data[row]);
|
||||||
|
}
|
||||||
|
|
||||||
ArrayJoinResultIterator::ArrayJoinResultIterator(const ArrayJoinAction * array_join_, Block block_)
|
ArrayJoinResultIterator::ArrayJoinResultIterator(const ArrayJoinAction * array_join_, Block block_)
|
||||||
: array_join(array_join_), block(std::move(block_)), total_rows(block.rows()), current_row(0)
|
: array_join(array_join_), block(std::move(block_)), total_rows(block.rows()), current_row(0)
|
||||||
@ -111,7 +144,6 @@ ArrayJoinResultIterator::ArrayJoinResultIterator(const ArrayJoinAction * array_j
|
|||||||
bool is_unaligned = array_join->is_unaligned;
|
bool is_unaligned = array_join->is_unaligned;
|
||||||
bool is_left = array_join->is_left;
|
bool is_left = array_join->is_left;
|
||||||
const auto & function_length = array_join->function_length;
|
const auto & function_length = array_join->function_length;
|
||||||
const auto & function_greatest = array_join->function_greatest;
|
|
||||||
const auto & function_array_resize = array_join->function_array_resize;
|
const auto & function_array_resize = array_join->function_array_resize;
|
||||||
const auto & function_builder = array_join->function_builder;
|
const auto & function_builder = array_join->function_builder;
|
||||||
|
|
||||||
@ -125,11 +157,7 @@ ArrayJoinResultIterator::ArrayJoinResultIterator(const ArrayJoinAction * array_j
|
|||||||
/// Resize all array joined columns to the longest one, (at least 1 if LEFT ARRAY JOIN), padded with default values.
|
/// Resize all array joined columns to the longest one, (at least 1 if LEFT ARRAY JOIN), padded with default values.
|
||||||
auto rows = block.rows();
|
auto rows = block.rows();
|
||||||
auto uint64 = std::make_shared<DataTypeUInt64>();
|
auto uint64 = std::make_shared<DataTypeUInt64>();
|
||||||
ColumnWithTypeAndName column_of_max_length{{}, uint64, {}};
|
auto max_length = ColumnUInt64::create(rows, (is_left ? 1u : 0u));
|
||||||
if (is_left)
|
|
||||||
column_of_max_length = ColumnWithTypeAndName(uint64->createColumnConst(rows, 1u), uint64, {});
|
|
||||||
else
|
|
||||||
column_of_max_length = ColumnWithTypeAndName(uint64->createColumnConst(rows, 0u), uint64, {});
|
|
||||||
|
|
||||||
for (const auto & name : columns)
|
for (const auto & name : columns)
|
||||||
{
|
{
|
||||||
@ -138,11 +166,10 @@ ArrayJoinResultIterator::ArrayJoinResultIterator(const ArrayJoinAction * array_j
|
|||||||
ColumnWithTypeAndName array_col = convertArrayJoinColumn(src_col);
|
ColumnWithTypeAndName array_col = convertArrayJoinColumn(src_col);
|
||||||
ColumnsWithTypeAndName tmp_block{array_col}; //, {{}, uint64, {}}};
|
ColumnsWithTypeAndName tmp_block{array_col}; //, {{}, uint64, {}}};
|
||||||
auto len_col = function_length->build(tmp_block)->execute(tmp_block, uint64, rows);
|
auto len_col = function_length->build(tmp_block)->execute(tmp_block, uint64, rows);
|
||||||
|
updateMaxLength(*max_length, *len_col);
|
||||||
ColumnsWithTypeAndName tmp_block2{column_of_max_length, {len_col, uint64, {}}};
|
|
||||||
column_of_max_length.column = function_greatest->build(tmp_block2)->execute(tmp_block2, uint64, rows);
|
|
||||||
}
|
}
|
||||||
|
|
||||||
|
ColumnWithTypeAndName column_of_max_length{std::move(max_length), uint64, {}};
|
||||||
for (const auto & name : columns)
|
for (const auto & name : columns)
|
||||||
{
|
{
|
||||||
auto & src_col = block.getByName(name);
|
auto & src_col = block.getByName(name);
|
||||||
|
@ -33,14 +33,14 @@ public:
|
|||||||
|
|
||||||
/// For unaligned [LEFT] ARRAY JOIN
|
/// For unaligned [LEFT] ARRAY JOIN
|
||||||
FunctionOverloadResolverPtr function_length;
|
FunctionOverloadResolverPtr function_length;
|
||||||
FunctionOverloadResolverPtr function_greatest;
|
//FunctionOverloadResolverPtr function_greatest;
|
||||||
FunctionOverloadResolverPtr function_array_resize;
|
FunctionOverloadResolverPtr function_array_resize;
|
||||||
|
|
||||||
/// For LEFT ARRAY JOIN.
|
/// For LEFT ARRAY JOIN.
|
||||||
FunctionOverloadResolverPtr function_builder;
|
FunctionOverloadResolverPtr function_builder;
|
||||||
|
|
||||||
ArrayJoinAction(const NameSet & array_joined_columns_, bool array_join_is_left, ContextPtr context);
|
ArrayJoinAction(const NameSet & array_joined_columns_, bool is_left_, bool is_unaligned_, size_t max_block_size_);
|
||||||
void prepare(ColumnsWithTypeAndName & sample) const;
|
static void prepare(const NameSet & columns, ColumnsWithTypeAndName & sample);
|
||||||
|
|
||||||
ArrayJoinResultIteratorPtr execute(Block block);
|
ArrayJoinResultIteratorPtr execute(Block block);
|
||||||
};
|
};
|
||||||
|
@ -215,7 +215,7 @@ NamesAndTypesList ExpressionAnalyzer::getColumnsAfterArrayJoin(ActionsDAG & acti
|
|||||||
|
|
||||||
auto array_join = addMultipleArrayJoinAction(actions, is_array_join_left);
|
auto array_join = addMultipleArrayJoinAction(actions, is_array_join_left);
|
||||||
auto sample_columns = actions.getResultColumns();
|
auto sample_columns = actions.getResultColumns();
|
||||||
array_join->prepare(sample_columns);
|
ArrayJoinAction::prepare(array_join->columns, sample_columns);
|
||||||
actions = ActionsDAG(sample_columns);
|
actions = ActionsDAG(sample_columns);
|
||||||
|
|
||||||
NamesAndTypesList new_columns_after_array_join;
|
NamesAndTypesList new_columns_after_array_join;
|
||||||
@ -905,7 +905,8 @@ ArrayJoinActionPtr ExpressionAnalyzer::addMultipleArrayJoinAction(ActionsDAG & a
|
|||||||
result_columns.insert(result_source.first);
|
result_columns.insert(result_source.first);
|
||||||
}
|
}
|
||||||
|
|
||||||
return std::make_shared<ArrayJoinAction>(result_columns, array_join_is_left, getContext());
|
const auto & query_settings = getContext()->getSettingsRef();
|
||||||
|
return std::make_shared<ArrayJoinAction>(result_columns, array_join_is_left, query_settings.enable_unaligned_array_join, query_settings.max_block_size);
|
||||||
}
|
}
|
||||||
|
|
||||||
ArrayJoinActionPtr SelectQueryExpressionAnalyzer::appendArrayJoin(ExpressionActionsChain & chain, ActionsAndProjectInputsFlagPtr & before_array_join, bool only_types)
|
ArrayJoinActionPtr SelectQueryExpressionAnalyzer::appendArrayJoin(ExpressionActionsChain & chain, ActionsAndProjectInputsFlagPtr & before_array_join, bool only_types)
|
||||||
|
@ -86,6 +86,7 @@
|
|||||||
#include <Core/Settings.h>
|
#include <Core/Settings.h>
|
||||||
#include <Core/ServerSettings.h>
|
#include <Core/ServerSettings.h>
|
||||||
#include <Interpreters/Aggregator.h>
|
#include <Interpreters/Aggregator.h>
|
||||||
|
#include <Interpreters/ArrayJoinAction.h>
|
||||||
#include <Interpreters/HashTablesStatistics.h>
|
#include <Interpreters/HashTablesStatistics.h>
|
||||||
#include <Interpreters/IJoin.h>
|
#include <Interpreters/IJoin.h>
|
||||||
#include <QueryPipeline/SizeLimits.h>
|
#include <QueryPipeline/SizeLimits.h>
|
||||||
@ -1655,7 +1656,12 @@ void InterpreterSelectQuery::executeImpl(QueryPlan & query_plan, std::optional<P
|
|||||||
if (expressions.array_join)
|
if (expressions.array_join)
|
||||||
{
|
{
|
||||||
QueryPlanStepPtr array_join_step
|
QueryPlanStepPtr array_join_step
|
||||||
= std::make_unique<ArrayJoinStep>(query_plan.getCurrentDataStream(), expressions.array_join);
|
= std::make_unique<ArrayJoinStep>(
|
||||||
|
query_plan.getCurrentDataStream(),
|
||||||
|
expressions.array_join->columns,
|
||||||
|
expressions.array_join->is_left,
|
||||||
|
expressions.array_join->is_unaligned,
|
||||||
|
expressions.array_join->max_block_size);
|
||||||
|
|
||||||
array_join_step->setStepDescription("ARRAY JOIN");
|
array_join_step->setStepDescription("ARRAY JOIN");
|
||||||
query_plan.addStep(std::move(array_join_step));
|
query_plan.addStep(std::move(array_join_step));
|
||||||
|
@ -1720,8 +1720,14 @@ JoinTreeQueryPlan buildQueryPlanForArrayJoinNode(const QueryTreeNodePtr & array_
|
|||||||
drop_unused_columns_before_array_join_transform_step->setStepDescription("DROP unused columns before ARRAY JOIN");
|
drop_unused_columns_before_array_join_transform_step->setStepDescription("DROP unused columns before ARRAY JOIN");
|
||||||
plan.addStep(std::move(drop_unused_columns_before_array_join_transform_step));
|
plan.addStep(std::move(drop_unused_columns_before_array_join_transform_step));
|
||||||
|
|
||||||
auto array_join_action = std::make_shared<ArrayJoinAction>(array_join_column_names, array_join_node.isLeft(), planner_context->getQueryContext());
|
const auto & settings = planner_context->getQueryContext()->getSettingsRef();
|
||||||
auto array_join_step = std::make_unique<ArrayJoinStep>(plan.getCurrentDataStream(), std::move(array_join_action));
|
auto array_join_step = std::make_unique<ArrayJoinStep>(
|
||||||
|
plan.getCurrentDataStream(),
|
||||||
|
std::move(array_join_column_names),
|
||||||
|
array_join_node.isLeft(),
|
||||||
|
settings.enable_unaligned_array_join,
|
||||||
|
settings.max_block_size);
|
||||||
|
|
||||||
array_join_step->setStepDescription("ARRAY JOIN");
|
array_join_step->setStepDescription("ARRAY JOIN");
|
||||||
plan.addStep(std::move(array_join_step));
|
plan.addStep(std::move(array_join_step));
|
||||||
|
|
||||||
|
@ -24,23 +24,27 @@ static ITransformingStep::Traits getTraits()
|
|||||||
};
|
};
|
||||||
}
|
}
|
||||||
|
|
||||||
ArrayJoinStep::ArrayJoinStep(const DataStream & input_stream_, ArrayJoinActionPtr array_join_)
|
ArrayJoinStep::ArrayJoinStep(const DataStream & input_stream_, NameSet columns_, bool is_left_, bool is_unaligned_, size_t max_block_size_)
|
||||||
: ITransformingStep(
|
: ITransformingStep(
|
||||||
input_stream_,
|
input_stream_,
|
||||||
ArrayJoinTransform::transformHeader(input_stream_.header, array_join_),
|
ArrayJoinTransform::transformHeader(input_stream_.header, columns_),
|
||||||
getTraits())
|
getTraits())
|
||||||
, array_join(std::move(array_join_))
|
, columns(std::move(columns_))
|
||||||
|
, is_left(is_left_)
|
||||||
|
, is_unaligned(is_unaligned_)
|
||||||
|
, max_block_size(max_block_size_)
|
||||||
{
|
{
|
||||||
}
|
}
|
||||||
|
|
||||||
void ArrayJoinStep::updateOutputStream()
|
void ArrayJoinStep::updateOutputStream()
|
||||||
{
|
{
|
||||||
output_stream = createOutputStream(
|
output_stream = createOutputStream(
|
||||||
input_streams.front(), ArrayJoinTransform::transformHeader(input_streams.front().header, array_join), getDataStreamTraits());
|
input_streams.front(), ArrayJoinTransform::transformHeader(input_streams.front().header, columns), getDataStreamTraits());
|
||||||
}
|
}
|
||||||
|
|
||||||
void ArrayJoinStep::transformPipeline(QueryPipelineBuilder & pipeline, const BuildQueryPipelineSettings &)
|
void ArrayJoinStep::transformPipeline(QueryPipelineBuilder & pipeline, const BuildQueryPipelineSettings &)
|
||||||
{
|
{
|
||||||
|
auto array_join = std::make_shared<ArrayJoinAction>(columns, is_left, is_unaligned, max_block_size);
|
||||||
pipeline.addSimpleTransform([&](const Block & header, QueryPipelineBuilder::StreamType stream_type)
|
pipeline.addSimpleTransform([&](const Block & header, QueryPipelineBuilder::StreamType stream_type)
|
||||||
{
|
{
|
||||||
bool on_totals = stream_type == QueryPipelineBuilder::StreamType::Totals;
|
bool on_totals = stream_type == QueryPipelineBuilder::StreamType::Totals;
|
||||||
@ -53,8 +57,8 @@ void ArrayJoinStep::describeActions(FormatSettings & settings) const
|
|||||||
String prefix(settings.offset, ' ');
|
String prefix(settings.offset, ' ');
|
||||||
bool first = true;
|
bool first = true;
|
||||||
|
|
||||||
settings.out << prefix << (array_join->is_left ? "LEFT " : "") << "ARRAY JOIN ";
|
settings.out << prefix << (is_left ? "LEFT " : "") << "ARRAY JOIN ";
|
||||||
for (const auto & column : array_join->columns)
|
for (const auto & column : columns)
|
||||||
{
|
{
|
||||||
if (!first)
|
if (!first)
|
||||||
settings.out << ", ";
|
settings.out << ", ";
|
||||||
@ -68,10 +72,10 @@ void ArrayJoinStep::describeActions(FormatSettings & settings) const
|
|||||||
|
|
||||||
void ArrayJoinStep::describeActions(JSONBuilder::JSONMap & map) const
|
void ArrayJoinStep::describeActions(JSONBuilder::JSONMap & map) const
|
||||||
{
|
{
|
||||||
map.add("Left", array_join->is_left);
|
map.add("Left", is_left);
|
||||||
|
|
||||||
auto columns_array = std::make_unique<JSONBuilder::JSONArray>();
|
auto columns_array = std::make_unique<JSONBuilder::JSONArray>();
|
||||||
for (const auto & column : array_join->columns)
|
for (const auto & column : columns)
|
||||||
columns_array->add(column);
|
columns_array->add(column);
|
||||||
|
|
||||||
map.add("Columns", std::move(columns_array));
|
map.add("Columns", std::move(columns_array));
|
||||||
|
@ -10,7 +10,7 @@ using ArrayJoinActionPtr = std::shared_ptr<ArrayJoinAction>;
|
|||||||
class ArrayJoinStep : public ITransformingStep
|
class ArrayJoinStep : public ITransformingStep
|
||||||
{
|
{
|
||||||
public:
|
public:
|
||||||
explicit ArrayJoinStep(const DataStream & input_stream_, ArrayJoinActionPtr array_join_);
|
ArrayJoinStep(const DataStream & input_stream_, NameSet columns_, bool is_left_, bool is_unaligned_, size_t max_block_size_);
|
||||||
String getName() const override { return "ArrayJoin"; }
|
String getName() const override { return "ArrayJoin"; }
|
||||||
|
|
||||||
void transformPipeline(QueryPipelineBuilder & pipeline, const BuildQueryPipelineSettings &) override;
|
void transformPipeline(QueryPipelineBuilder & pipeline, const BuildQueryPipelineSettings &) override;
|
||||||
@ -18,12 +18,16 @@ public:
|
|||||||
void describeActions(JSONBuilder::JSONMap & map) const override;
|
void describeActions(JSONBuilder::JSONMap & map) const override;
|
||||||
void describeActions(FormatSettings & settings) const override;
|
void describeActions(FormatSettings & settings) const override;
|
||||||
|
|
||||||
const ArrayJoinActionPtr & arrayJoin() const { return array_join; }
|
const NameSet & getColumns() const { return columns; }
|
||||||
|
bool isLeft() const { return is_left; }
|
||||||
|
|
||||||
private:
|
private:
|
||||||
void updateOutputStream() override;
|
void updateOutputStream() override;
|
||||||
|
|
||||||
ArrayJoinActionPtr array_join;
|
NameSet columns;
|
||||||
|
bool is_left = false;
|
||||||
|
bool is_unaligned = false;
|
||||||
|
size_t max_block_size = DEFAULT_BLOCK_SIZE;
|
||||||
};
|
};
|
||||||
|
|
||||||
}
|
}
|
||||||
|
@ -520,8 +520,7 @@ size_t tryPushDownFilter(QueryPlan::Node * parent_node, QueryPlan::Nodes & nodes
|
|||||||
|
|
||||||
if (auto * array_join = typeid_cast<ArrayJoinStep *>(child.get()))
|
if (auto * array_join = typeid_cast<ArrayJoinStep *>(child.get()))
|
||||||
{
|
{
|
||||||
const auto & array_join_actions = array_join->arrayJoin();
|
const auto & keys = array_join->getColumns();
|
||||||
const auto & keys = array_join_actions->columns;
|
|
||||||
const auto & array_join_header = array_join->getInputStreams().front().header;
|
const auto & array_join_header = array_join->getInputStreams().front().header;
|
||||||
|
|
||||||
Names allowed_inputs;
|
Names allowed_inputs;
|
||||||
|
@ -24,11 +24,11 @@ size_t tryLiftUpArrayJoin(QueryPlan::Node * parent_node, QueryPlan::Nodes & node
|
|||||||
if (!(expression_step || filter_step) || !array_join_step)
|
if (!(expression_step || filter_step) || !array_join_step)
|
||||||
return 0;
|
return 0;
|
||||||
|
|
||||||
const auto & array_join = array_join_step->arrayJoin();
|
const auto & array_join_columns = array_join_step->getColumns();
|
||||||
const auto & expression = expression_step ? expression_step->getExpression()
|
const auto & expression = expression_step ? expression_step->getExpression()
|
||||||
: filter_step->getExpression();
|
: filter_step->getExpression();
|
||||||
|
|
||||||
auto split_actions = expression.splitActionsBeforeArrayJoin(array_join->columns);
|
auto split_actions = expression.splitActionsBeforeArrayJoin(array_join_columns);
|
||||||
|
|
||||||
/// No actions can be moved before ARRAY JOIN.
|
/// No actions can be moved before ARRAY JOIN.
|
||||||
if (split_actions.first.trivial())
|
if (split_actions.first.trivial())
|
||||||
|
@ -230,10 +230,10 @@ void buildSortingDAG(QueryPlan::Node & node, std::optional<ActionsDAG> & dag, Fi
|
|||||||
{
|
{
|
||||||
/// Should ignore limit because ARRAY JOIN can reduce the number of rows in case of empty array.
|
/// Should ignore limit because ARRAY JOIN can reduce the number of rows in case of empty array.
|
||||||
/// But in case of LEFT ARRAY JOIN the result number of rows is always bigger.
|
/// But in case of LEFT ARRAY JOIN the result number of rows is always bigger.
|
||||||
if (!array_join->arrayJoin()->is_left)
|
if (!array_join->isLeft())
|
||||||
limit = 0;
|
limit = 0;
|
||||||
|
|
||||||
const auto & array_joined_columns = array_join->arrayJoin()->columns;
|
const auto & array_joined_columns = array_join->getColumns();
|
||||||
|
|
||||||
if (dag)
|
if (dag)
|
||||||
{
|
{
|
||||||
|
@ -10,10 +10,10 @@ namespace ErrorCodes
|
|||||||
extern const int LOGICAL_ERROR;
|
extern const int LOGICAL_ERROR;
|
||||||
}
|
}
|
||||||
|
|
||||||
Block ArrayJoinTransform::transformHeader(Block header, const ArrayJoinActionPtr & array_join)
|
Block ArrayJoinTransform::transformHeader(Block header, const NameSet & array_join_columns)
|
||||||
{
|
{
|
||||||
auto columns = header.getColumnsWithTypeAndName();
|
auto columns = header.getColumnsWithTypeAndName();
|
||||||
array_join->prepare(columns);
|
ArrayJoinAction::prepare(array_join_columns, columns);
|
||||||
Block res{std::move(columns)};
|
Block res{std::move(columns)};
|
||||||
res.setColumns(res.mutateColumns());
|
res.setColumns(res.mutateColumns());
|
||||||
return res;
|
return res;
|
||||||
@ -23,7 +23,7 @@ ArrayJoinTransform::ArrayJoinTransform(
|
|||||||
const Block & header_,
|
const Block & header_,
|
||||||
ArrayJoinActionPtr array_join_,
|
ArrayJoinActionPtr array_join_,
|
||||||
bool /*on_totals_*/)
|
bool /*on_totals_*/)
|
||||||
: IInflatingTransform(header_, transformHeader(header_, array_join_))
|
: IInflatingTransform(header_, transformHeader(header_, array_join_->columns))
|
||||||
, array_join(std::move(array_join_))
|
, array_join(std::move(array_join_))
|
||||||
{
|
{
|
||||||
/// TODO
|
/// TODO
|
||||||
|
@ -22,7 +22,7 @@ public:
|
|||||||
|
|
||||||
String getName() const override { return "ArrayJoinTransform"; }
|
String getName() const override { return "ArrayJoinTransform"; }
|
||||||
|
|
||||||
static Block transformHeader(Block header, const ArrayJoinActionPtr & array_join);
|
static Block transformHeader(Block header, const NameSet & array_join_columns);
|
||||||
|
|
||||||
protected:
|
protected:
|
||||||
void consume(Chunk chunk) override;
|
void consume(Chunk chunk) override;
|
||||||
|
Loading…
Reference in New Issue
Block a user