You are viewing a plain text version of this content. The canonical link for it is here.
Posted to user@kylin.apache.org by 知猪侠 <38...@qq.com> on 2018/12/13 02:54:28 UTC

回复: Didn't find KYLIN_CONF or KYLIN_HOME, please set one of them

Hi, Lijun Cao:
On kylin node, I have exported KYLIN_HOME as environment variable, and all cubes have been running for more than one month, this problem was suddenly happened.


I found a url : https://issues.apache.org/jira/browse/KYLIN-1229?jql=text%20~%20%22Didn%27t%20find%20KYLIN_CONF%20or%20KYLIN_HOME%2C%20please%20set%20one%20of%20them%22
It says about "Didn't find KYLIN_CONF or KYLIN_HOME, please set one of them", it was reported by Shaofeng SHI, but I'm not sure if it is similar to my problem.


Thank you!




------------------ 原始邮件 ------------------
发件人: "Lijun Cao"<64...@qq.com>;
发送时间: 2018年12月13日(星期四) 上午10:27
收件人: "user"<us...@kylin.apache.org>;

主题: Re: Didn't find KYLIN_CONF or KYLIN_HOME, please set one of them



Hi, 知猪侠:

Have you try to export KYLIN_HOME as environment variable? 


Best Regards


Lijun Cao

在 2018年12月11日,10:05,知猪侠 <38...@qq.com> 写道:

My kylin version is 2.5.0 cdh57, my cube has been running for more than one month, when I merged cube yesterday,  I encountered the following error:
18/12/10 18:05:59 WARN scheduler.TaskSetManager: Lost task 4.0 in stage 2.0 (TID 24, pro04.cdh.ecarx.local, executor 1): com.google.common.util.concurrent.UncheckedExecutionException: org.apache.kylin.common.KylinConfigCannotInitException: Didn't find KYLIN_CONF or KYLIN_HOME, please set one of them 	at com.google.common.cache.LocalCache\$Segment.get(LocalCache.java:2263) 	at com.google.common.cache.LocalCache.get(LocalCache.java:4000) 	at com.google.common.cache.LocalCache.getOrLoad(LocalCache.java:4004) 	at com.google.common.cache.LocalCache\$LocalLoadingCache.get(LocalCache.java:4874) 	at org.apache.kylin.dict.DictionaryManager.getDictionaryInfo(DictionaryManager.java:103) 	at org.apache.kylin.cube.CubeManager\$DictionaryAssist.getDictionary(CubeManager.java:1095) 	at org.apache.kylin.cube.CubeManager.getDictionary(CubeManager.java:1028) 	at org.apache.kylin.cube.CubeSegment.getDictionary(CubeSegment.java:328) 	at org.apache.kylin.engine.mr.steps.SegmentReEncoder.init(SegmentReEncoder.java:100) 	at org.apache.kylin.engine.mr.steps.SegmentReEncoder.(SegmentReEncoder.java:77) 	at org.apache.kylin.engine.spark.SparkCubingMerge\$ReEncodCuboidFunction.init(SparkCubingMerge.java:264) 	at org.apache.kylin.engine.spark.SparkCubingMerge\$ReEncodCuboidFunction.call(SparkCubingMerge.java:272) 	at org.apache.kylin.engine.spark.SparkCubingMerge\$ReEncodCuboidFunction.call(SparkCubingMerge.java:238) 	at org.apache.spark.api.java.JavaPairRDD\$\$anonfun\$pairFunToScalaFun\$1.apply(JavaPairRDD.scala:1043) 	at org.apache.spark.api.java.JavaPairRDD\$\$anonfun\$pairFunToScalaFun\$1.apply(JavaPairRDD.scala:1043) 	at scala.collection.Iterator\$\$anon\$11.next(Iterator.scala:409) 	at org.apache.spark.util.collection.ExternalSorter.insertAll(ExternalSorter.scala:193) 	at org.apache.spark.shuffle.sort.SortShuffleWriter.write(SortShuffleWriter.scala:63) 	at org.apache.spark.scheduler.ShuffleMapTask.runTask(ShuffleMapTask.scala:96) 	at org.apache.spark.scheduler.ShuffleMapTask.runTask(ShuffleMapTask.scala:53) 	at org.apache.spark.scheduler.Task.run(Task.scala:99) 	at org.apache.spark.executor.Executor\$TaskRunner.run(Executor.scala:325) 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142) 	at java.util.concurrent.ThreadPoolExecutor\$Worker.run(ThreadPoolExecutor.java:617) 	at java.lang.Thread.run(Thread.java:745) Caused by: org.apache.kylin.common.KylinConfigCannotInitException: Didn't find KYLIN_CONF or KYLIN_HOME, please set one of them 	at org.apache.kylin.common.KylinConfig.getSitePropertiesFile(KylinConfig.java:295) 	at org.apache.kylin.common.KylinConfig.buildSiteOrderedProps(KylinConfig.java:347) 	at org.apache.kylin.common.KylinConfig.buildSiteProperties(KylinConfig.java:316) 	at org.apache.kylin.common.KylinConfig.getInstanceFromEnv(KylinConfig.java:97) 	at org.apache.kylin.dict.AppendTrieDictionary.convertToAbsolutePath(AppendTrieDictionary.java:211) 	at org.apache.kylin.dict.AppendTrieDictionary.init(AppendTrieDictionary.java:75) 	at org.apache.kylin.dict.AppendTrieDictionary.readFields(AppendTrieDictionary.java:160) 	at org.apache.kylin.dict.DictionaryInfoSerializer.deserialize(DictionaryInfoSerializer.java:74) 	at org.apache.kylin.dict.DictionaryInfoSerializer.deserialize(DictionaryInfoSerializer.java:34) 	at org.apache.kylin.common.persistence.ResourceStore.getResource(ResourceStore.java:181) 	at org.apache.kylin.dict.DictionaryManager.load(DictionaryManager.java:407) 	at org.apache.kylin.dict.DictionaryManager\$1.load(DictionaryManager.java:82) 	at org.apache.kylin.dict.DictionaryManager\$1.load(DictionaryManager.java:79) 	at com.google.common.cache.LocalCache\$LoadingValueReference.loadFuture(LocalCache.java:3599) 	at com.google.common.cache.LocalCache\$Segment.loadSync(LocalCache.java:2379) 	at com.google.common.cache.LocalCache\$Segment.lockedGetOrLoad(LocalCache.java:2342) 	at com.google.common.cache.LocalCache\$Segment.get(LocalCache.java:2257) 	... 24 more
I've searched a lot of information, but I haven't found a solution yet. Who has ever encountered this problem?See attachment for detailed log.Thank you very much!
 
<traffic_test_cube.log>