blob: 3407a15d11727ae38244f131968cac8ea2fc0931 [file] [log] [blame]
// Licensed to the Apache Software Foundation (ASF) under one
// or more contributor license agreements. See the NOTICE file
// distributed with this work for additional information
// regarding copyright ownership. The ASF licenses this file
// to you under the Apache License, Version 2.0 (the
// "License"); you may not use this file except in compliance
// with the License. You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing,
// software distributed under the License is distributed on an
// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
// KIND, either express or implied. See the License for the
// specific language governing permissions and limitations
// under the License.
#include <gtest/gtest.h>
#include <string>
#include <vector>
#include "common/object_pool.h"
#include "cpp/sync_point.h"
#include "gen_cpp/Descriptors_types.h"
#include "gen_cpp/PlanNodes_types.h"
#include "io/fs/local_file_system.h"
#include "olap/wal/wal_manager.h"
#include "pipeline/exec/file_scan_operator.h"
#include "runtime/cluster_info.h"
#include "runtime/descriptors.h"
#include "runtime/memory/mem_tracker.h"
#include "runtime/runtime_state.h"
#include "runtime/user_function_cache.h"
#include "vec/exec/scan/file_scanner.h"
namespace doris {
namespace vectorized {
class TestSplitSourceConnectorStub : public SplitSourceConnector {
private:
std::mutex _range_lock;
TFileScanRange _scan_range;
int _range_index = 0;
public:
TestSplitSourceConnectorStub(const TFileScanRange& scan_range) : _scan_range(scan_range) {}
Status get_next(bool* has_next, TFileRangeDesc* range) override {
std::lock_guard<std::mutex> l(_range_lock);
if (_range_index < _scan_range.ranges.size()) {
*has_next = true;
*range = _scan_range.ranges[_range_index++];
} else {
*has_next = false;
}
return Status::OK();
}
int num_scan_ranges() override { return _scan_range.ranges.size(); }
TFileScanRangeParams* get_params() override { return &_scan_range.params; }
};
class VfileScannerExceptionTest : public testing::Test {
public:
VfileScannerExceptionTest()
: _runtime_state(TQueryOptions(), TQueryGlobals()),
_global_profile("<global profile>") {
_runtime_state.resize_op_id_to_local_state(-1);
init();
_profile = _runtime_state.runtime_profile();
WARN_IF_ERROR(_runtime_state.init(_unique_id, _query_options, _query_globals, _env),
"fail to init _runtime_state");
}
void init();
void generate_scanner(std::shared_ptr<FileScanner>& scanner);
void TearDown() override {
WARN_IF_ERROR(_scan_node->close(&_runtime_state), "fail to close scan_node")
}
protected:
virtual void SetUp() override {}
private:
void _init_desc_table();
ExecEnv* _env = nullptr;
int64_t _backend_id = 1001;
std::string _label_1 = "test1";
std::string _label_2 = "test2";
TupleId _dst_tuple_id = 0;
RuntimeState _runtime_state;
RuntimeProfile _global_profile;
RuntimeProfile* _profile;
ObjectPool _obj_pool;
DescriptorTbl* _desc_tbl;
std::vector<TNetworkAddress> _addresses;
ScannerCounter _counter;
std::vector<TExpr> _pre_filter;
TPlanNode _tnode;
TUniqueId _unique_id;
TQueryOptions _query_options;
TQueryGlobals _query_globals;
std::shared_ptr<pipeline::FileScanOperatorX> _scan_node = nullptr;
std::vector<TFileRangeDesc> _ranges;
TFileRangeDesc _range_desc;
TFileScanRange _scan_range;
std::unique_ptr<ShardedKVCache> _kv_cache = nullptr;
std::unique_ptr<ClusterInfo> _cluster_info = nullptr;
};
void VfileScannerExceptionTest::_init_desc_table() {
TDescriptorTable t_desc_table;
// table descriptors
TTableDescriptor t_table_desc;
t_table_desc.id = 0;
t_table_desc.tableType = TTableType::OLAP_TABLE;
t_table_desc.numCols = 0;
t_table_desc.numClusteringCols = 0;
t_desc_table.tableDescriptors.push_back(t_table_desc);
t_desc_table.__isset.tableDescriptors = true;
int next_slot_id = 1;
// TSlotDescriptor
// int offset = 1;
// int i = 0;
// c1
{
TSlotDescriptor slot_desc;
slot_desc.id = next_slot_id++;
slot_desc.parent = 0;
TTypeDesc type;
{
TTypeNode node;
node.__set_type(TTypeNodeType::SCALAR);
TScalarType scalar_type;
scalar_type.__set_type(TPrimitiveType::VARCHAR);
scalar_type.__set_len(32);
node.__set_scalar_type(scalar_type);
type.types.push_back(node);
}
slot_desc.slotType = type;
slot_desc.columnPos = 0;
slot_desc.byteOffset = 0;
slot_desc.nullIndicatorByte = 0;
slot_desc.nullIndicatorBit = -1;
slot_desc.colName = "c1";
slot_desc.slotIdx = 1;
slot_desc.col_unique_id = 0;
t_desc_table.slotDescriptors.push_back(slot_desc);
}
// c2
{
TSlotDescriptor slot_desc;
slot_desc.id = next_slot_id++;
slot_desc.parent = 0;
TTypeDesc type;
{
TTypeNode node;
node.__set_type(TTypeNodeType::SCALAR);
TScalarType scalar_type;
scalar_type.__set_type(TPrimitiveType::VARCHAR);
scalar_type.__set_len(32);
node.__set_scalar_type(scalar_type);
type.types.push_back(node);
}
slot_desc.slotType = type;
slot_desc.columnPos = 1;
slot_desc.byteOffset = 4;
slot_desc.nullIndicatorByte = 0;
slot_desc.nullIndicatorBit = -1;
slot_desc.colName = "c2";
slot_desc.slotIdx = 2;
slot_desc.col_unique_id = 1;
t_desc_table.slotDescriptors.push_back(slot_desc);
}
// c3
{
TSlotDescriptor slot_desc;
slot_desc.id = next_slot_id++;
slot_desc.parent = 0;
TTypeDesc type;
{
TTypeNode node;
node.__set_type(TTypeNodeType::SCALAR);
TScalarType scalar_type;
scalar_type.__set_type(TPrimitiveType::VARCHAR);
scalar_type.__set_len(32);
node.__set_scalar_type(scalar_type);
type.types.push_back(node);
}
slot_desc.slotType = type;
slot_desc.columnPos = 2;
slot_desc.byteOffset = 8;
slot_desc.nullIndicatorByte = 0;
slot_desc.nullIndicatorBit = -1;
slot_desc.colName = "c3";
slot_desc.slotIdx = 3;
slot_desc.col_unique_id = 2;
t_desc_table.slotDescriptors.push_back(slot_desc);
}
t_desc_table.__isset.slotDescriptors = true;
{
// TTupleDescriptor dest
TTupleDescriptor t_tuple_desc;
t_tuple_desc.id = 0;
t_tuple_desc.byteSize = 12;
t_tuple_desc.numNullBytes = 0;
t_tuple_desc.tableId = 0;
t_tuple_desc.__isset.tableId = true;
t_desc_table.tupleDescriptors.push_back(t_tuple_desc);
}
auto st = DescriptorTbl::create(&_obj_pool, t_desc_table, &_desc_tbl);
_runtime_state.set_desc_tbl(_desc_tbl);
}
void VfileScannerExceptionTest::init() {
_init_desc_table();
// Node Id
_tnode.node_id = 0;
_tnode.node_type = TPlanNodeType::FILE_SCAN_NODE;
_tnode.num_children = 0;
_tnode.limit = -1;
_tnode.row_tuples.push_back(0);
_tnode.file_scan_node.tuple_id = 0;
_tnode.__isset.file_scan_node = true;
_scan_node =
std::make_shared<pipeline::FileScanOperatorX>(&_obj_pool, _tnode, 0, *_desc_tbl, 1);
_scan_node->_output_tuple_desc = _runtime_state.desc_tbl().get_tuple_descriptor(_dst_tuple_id);
WARN_IF_ERROR(_scan_node->init(_tnode, &_runtime_state), "fail to init scan_node");
WARN_IF_ERROR(_scan_node->prepare(&_runtime_state), "fail to open scan_node");
auto local_state =
pipeline::FileScanLocalState::create_unique(&_runtime_state, _scan_node.get());
std::vector<TScanRangeParams> scan_ranges;
pipeline::LocalStateInfo info {.parent_profile = &_global_profile,
.scan_ranges = scan_ranges,
.shared_state = nullptr,
.shared_state_map = {},
.task_idx = 0};
WARN_IF_ERROR(local_state->init(&_runtime_state, info), "fail to init local_state");
_runtime_state.emplace_local_state(_scan_node->operator_id(), std::move(local_state));
_range_desc.start_offset = 0;
_range_desc.size = 1000;
_ranges.push_back(_range_desc);
_scan_range.ranges = _ranges;
_scan_range.__isset.params = true;
_scan_range.params.format_type = TFileFormatType::FORMAT_JNI;
_kv_cache.reset(new ShardedKVCache(48));
_cluster_info.reset(new ClusterInfo());
_env = ExecEnv::GetInstance();
_env->_cluster_info = _cluster_info.get();
_env->_cluster_info->master_fe_addr.hostname = "host name";
_env->_cluster_info->master_fe_addr.port = _backend_id;
_env->_cluster_info->backend_id = 1001;
_env->_wal_manager = 0;
}
void VfileScannerExceptionTest::generate_scanner(std::shared_ptr<FileScanner>& scanner) {
auto split_source = std::make_shared<TestSplitSourceConnectorStub>(_scan_range);
std::unordered_map<std::string, int> _colname_to_slot_id;
scanner = std::make_shared<FileScanner>(
&_runtime_state,
&(_runtime_state.get_local_state(0)->cast<pipeline::FileScanLocalState>()), -1,
split_source, _profile, _kv_cache.get(), &_colname_to_slot_id);
scanner->_is_load = false;
vectorized::VExprContextSPtrs _conjuncts;
WARN_IF_ERROR(scanner->init(&_runtime_state, _conjuncts), "fail to prepare scanner");
}
TEST_F(VfileScannerExceptionTest, failure_case) {
std::shared_ptr<FileScanner> scanner = nullptr;
generate_scanner(scanner);
std::unique_ptr<vectorized::Block> block(new vectorized::Block());
bool eof = false;
auto st = scanner->get_block(&_runtime_state, block.get(), &eof);
ASSERT_FALSE(st.ok());
auto msg = st.to_string();
auto pos = msg.find("Not supported create reader");
std::cout << "msg = " << msg << std::endl;
ASSERT_TRUE(pos != msg.npos);
WARN_IF_ERROR(scanner->close(&_runtime_state), "fail to close scanner");
}
} // namespace vectorized
} // namespace doris