You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by "copyshop (via GitHub)" <gi...@apache.org> on 2023/04/14 10:51:55 UTC

[GitHub] [doris] copyshop opened a new issue, #18684: [Bug] create routine load lead to be die

copyshop opened a new issue, #18684:
URL: https://github.com/apache/doris/issues/18684

   ### Search before asking
   
   - [X] I had searched in the [issues](https://github.com/apache/doris/issues?q=is%3Aissue) and found no similar issues.
   
   
   ### Version
   
   Version : doris-1.2.2-rc01
   
   BuildInfo : be0ca7388ef3
   
   BuildTime : Fri, 10 Feb 2023 16:43:32 UTC
   
   ### What's Wrong?
   
   be node shutdown because use routine load create label job .
   
   doris kafka consumer process lead to be node shutdown (one of three)
   
   use comand:
   SHOW ALL ROUTINE LOAD;
   
   14309	device_monitor_log_kafka_test_job	2023-04-11 19:16:05	2023-04-11 19:16:15		default_cluster:test	device_monitor_log_kafka_test	PAUSED	KAFKA	0	{"timezone":"Asia/Shanghai","send_batch_parallelism":"1","columnSeparator":"\t","load_to_single_tablet":"false","lineDelimiter":"\n","maxBatchSizeBytes":"209715200","exec_mem_limit":"2147483648","strict_mode":"false","jsonpaths":"","currentTaskConcurrentNum":"0","fuzzy_parse":"false","partitions":"*","columnToColumnExpr":"ctime,device_name,device_id,f1,f2,f3","maxBatchIntervalS":"20","whereExpr":"*","precedingFilter":"*","mergeType":"APPEND","format":"csv","json_root":"","deleteCondition":"*","desireTaskConcurrentNum":"5","maxErrorNum":"0","strip_outer_array":"false","execMemLimit":"2147483648","num_as_string":"false","maxBatchRows":"300000"}	{"topic":"device_monitor_log_kafka_test","currentKafkaPartitions":"","brokerList":"*********:9092"}	{"kafka_default_offsets":"OFFSET_BEGINNING","group.id":"device_monitor_log_kafka_test","client.id
 ":"device_monitor_log_kafka_test"}	{"receivedBytes":0,"runningTxns":[],"errorRows":0,"committedTaskNum":0,"loadedRows":0,"loadRowsRate":0,"abortedTaskNum":0,"errorRowsAfterResumed":0,"totalRows":0,"unselectedRows":0,"receivedBytesRate":0,"taskExecuteTimeMs":1}	{}	{}	ErrorReason{code=errCode = 4, msg='Job failed to fetch all current partition with error errCode = 2, detailMessage = Failed to get all partitions of kafka topic: device_monitor_log_kafka_test. error: io.grpc.StatusRuntimeException: UNAVAILABLE: Network closed for unknown reason'}
   
   I forgot to send the data example.
   
   我CREATE ROUTINE LOAD 好后,对应的使用kafkaTemplate 发送数据,(忘记当时发送什么样的数据,发送完后发现3个节点中的其中一个节点挂掉了)
   
   ![5aef969009d8917ccabd83812569318](https://user-images.githubusercontent.com/4143961/232024584-6e2af1fe-458b-4192-af70-68647a1b9fbc.png)
   
   `start time: Thu Apr  6 09:54:42 CST 2023
   *** Query id: 736b3d0f7421458a-a26e095395b37a40 ***
   *** Aborted at 1681211774 (unix time) try "date -d @1681211774" if you are using GNU date ***
   *** Current BE git commitID: Unknown ***
   *** SIGSEGV address not mapped to object (@0x48) received by PID 24876 (TID 0x7f0d7efa0700) from PID 72; stack trace: ***
    0# doris::signal::(anonymous namespace)::FailureSignalHandler(int, siginfo_t*, void*) at /root/doris/be/src/common/signal_handler.h:420
    1# os::Linux::chained_handler(int, siginfo*, void*) in /home/admin/software/jdk-11/lib/server/libjvm.so
    2# JVM_handle_linux_signal in /home/admin/software/jdk-11/lib/server/libjvm.so
    3# signalHandler(int, siginfo*, void*) in /home/admin/software/jdk-11/lib/server/libjvm.so
    4# 0x00007F0F45D18450 in /lib64/libc.so.6
    5# je_large_prof_tctx_get at ../src/large.c:374
    6# je_free_default at ../src/jemalloc.c:2790
    7# __GI__dl_deallocate_tls in /lib64/ld-linux-x86-64.so.2
    8# __free_stacks in /lib64/libpthread.so.0
    9# __deallocate_stack in /lib64/libpthread.so.0
   10# pthread_join in /lib64/libpthread.so.0
   11# thrd_join in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   12# 0x000055E279DC3CC5 in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   13# RdKafka::KafkaConsumerImpl::~KafkaConsumerImpl() in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   14# std::_Sp_counted_ptr_inplace<doris::KafkaDataConsumer, std::allocator<doris::KafkaDataConsumer>, (__gnu_cxx::_Lock_policy)2>::_M_dispose() at /var/local/ldb-toolchain/include/c++/11/bits/shared_ptr_base.h:528
   15# std::_Sp_counted_base<(__gnu_cxx::_Lock_policy)2>::_M_release() at /var/local/ldb-toolchain/include/c++/11/bits/shared_ptr_base.h:161
   16# doris::RoutineLoadTaskExecutor::get_kafka_partition_meta(doris::PKafkaMetaProxyRequest const&, std::vector<int, std::allocator<int> >*) at /root/doris/be/src/runtime/routine_load/routine_load_task_executor.cpp:106
   17# doris::PInternalServiceImpl::get_info(google::protobuf::RpcController*, doris::PProxyRequest const*, doris::PProxyResult*, google::protobuf::Closure*) at /root/doris/be/src/service/internal_service.cpp:545
   18# brpc::policy::ProcessHttpRequest(brpc::InputMessageBase*) in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   19# brpc::ProcessInputMessage(void*) in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   20# brpc::InputMessenger::OnNewMessages(brpc::Socket*) in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   21# brpc::Socket::ProcessEvent(void*) in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   22# bthread::TaskGroup::task_runner(long) in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be
   23# bthread_make_fcontext in /home/admin/software/apache-doris-be-1.2.2-bin-x86_64/lib/doris_be`
   
   
   
   ### What You Expected?
   
   I want to be run normal.
   
   ### How to Reproduce?
   
   _No response_
   
   ### Anything Else?
   
   _No response_
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of Conduct](https://www.apache.org/foundation/policies/conduct)
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org