You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@kylin.apache.org by zhangrongkun <56...@qq.com> on 2016/05/03 09:44:11 UTC

Re: My kylin cube build successfully,but when query I meet thisexception:

OK
2016-05-03 15:39:11,762 INFO  [http-bio-7070-exec-1]
controller.QueryController:174 : Using project: learn_kylin
2016-05-03 15:39:11,762 INFO  [http-bio-7070-exec-1]
controller.QueryController:175 : The original query:  select part_dt,
sum(price) as total_selled, count(distinct seller_id) as sellers from
kylin_sales group by part_dt order by part_dt
2016-05-03 15:39:11,764 INFO  [http-bio-7070-exec-1]
service.QueryService:264 : The corrected query: select part_dt, sum(price)
as total_selled, count(distinct seller_id) as sellers from kylin_sales group
by part_dt order by part_dt
LIMIT 5000
2016-05-03 15:39:11,981 INFO  [http-bio-7070-exec-1] routing.QueryRouter:48
: The project manager's reference is
org.apache.kylin.metadata.project.ProjectManager@376666f2
2016-05-03 15:39:11,982 INFO  [http-bio-7070-exec-1] routing.QueryRouter:60
: Find candidates by table DEFAULT.KYLIN_SALES and project=LEARN_KYLIN :
org.apache.kylin.query.routing.Candidate@9499af8
2016-05-03 15:39:11,983 INFO  [http-bio-7070-exec-1] routing.QueryRouter:49
: Applying rule: class
org.apache.kylin.query.routing.rules.RemoveUncapableRealizationsRule,
realizations before: [kylin_sales_cube(CUBE)], realizations after:
[kylin_sales_cube(CUBE)]
2016-05-03 15:39:11,983 INFO  [http-bio-7070-exec-1] routing.QueryRouter:49
: Applying rule: class
org.apache.kylin.query.routing.rules.RealizationSortRule, realizations
before: [kylin_sales_cube(CUBE)], realizations after:
[kylin_sales_cube(CUBE)]
2016-05-03 15:39:11,984 INFO  [http-bio-7070-exec-1] routing.QueryRouter:72
: The realizations remaining: [kylin_sales_cube(CUBE)] And the final chosen
one is the first one
2016-05-03 15:39:12,075 DEBUG [http-bio-7070-exec-1]
enumerator.OLAPEnumerator:107 : query storage...
2016-05-03 15:39:12,076 INFO  [http-bio-7070-exec-1] v2.CubeStorageQuery:251
: exactAggregation is true
2016-05-03 15:39:12,077 INFO  [http-bio-7070-exec-1] v2.CubeStorageQuery:357
: Memory budget is set to: 3109290
2016-05-03 15:39:12,078 DEBUG [http-bio-7070-exec-1]
v2.CubeHBaseEndpointRPC:257 : New scanner for current segment
kylin_sales_cube[20120101000000_20160529000000] will use
SCAN_FILTER_AGGR_CHECKMEM as endpoint's behavior
2016-05-03 15:39:12,079 DEBUG [http-bio-7070-exec-1]
v2.CubeHBaseEndpointRPC:292 : Serialized scanRequestBytes 321 bytes,
rawScanBytesString 46 bytes
2016-05-03 15:39:12,080 INFO  [http-bio-7070-exec-1]
v2.CubeHBaseEndpointRPC:295 : The scan(s) info for current segment is as
below, shard part of start/end key is set to 0
2016-05-03 15:39:12,082 INFO  [http-bio-7070-exec-1] v2.CubeHBaseRPC:309 :
Visiting hbase table KYLIN_U9OEMLU034: cuboid exact match, from 64 to 64
Start: \x00\x00\x00\x00\x00\x00\x00\x00\x00\x40\x00\x00\x00
(\x00\x00\x00\x00\x00\x00\x00\x00\x00@\x00\x00\x00) Stop: 
\x00\x00\x00\x00\x00\x00\x00\x00\x00\x40\xFF\xFF\xFF\x00
(\x00\x00\x00\x00\x00\x00\x00\x00\x00@\xFF\xFF\xFF\x00), No Fuzzy Key
2016-05-03 15:39:12,083 DEBUG [http-bio-7070-exec-1]
v2.CubeHBaseEndpointRPC:301 : Submitting rpc to 1 shards starting from shard
0, scan requests count 1
2016-05-03 15:39:12,104 INFO  [http-bio-7070-exec-1]
v2.CubeHBaseEndpointRPC:126 : Timeout for ExpectedSizeIterator is 60000
2016-05-03 15:39:12,105 DEBUG [http-bio-7070-exec-1]
enumerator.OLAPEnumerator:127 : return TupleIterator...
2016-05-03 15:39:12,111 ERROR [pool-12-thread-2] v2.CubeHBaseEndpointRPC:99
: Execution exception when running task in pool-12-thread-2
2016-05-03 15:39:12,112 ERROR [pool-12-thread-2] v2.CubeHBaseEndpointRPC:109
: Caught exception in thread pool-12-thread-2: 
java.lang.RuntimeException: Error when visiting cubes by endpoint:
	at
org.apache.kylin.storage.hbase.cube.v2.CubeHBaseEndpointRPC$1.run(CubeHBaseEndpointRPC.java:324)
	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:471)
	at java.util.concurrent.FutureTask.run(FutureTask.java:262)
	at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
	at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
	at java.lang.Thread.run(Thread.java:745)
Caused by: org.apache.hadoop.hbase.DoNotRetryIOException:
org.apache.hadoop.hbase.DoNotRetryIOException: java.lang.NoSuchMethodError:
org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment.getRegion()Lorg/apache/hadoop/hbase/regionserver/Region;
	at org.apache.hadoop.hbase.ipc.RpcServer.call(RpcServer.java:2062)
	at org.apache.hadoop.hbase.ipc.CallRunner.run(CallRunner.java:107)
	at
org.apache.hadoop.hbase.ipc.RpcExecutor.consumerLoop(RpcExecutor.java:130)
	at org.apache.hadoop.hbase.ipc.RpcExecutor$1.run(RpcExecutor.java:107)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.NoSuchMethodError:
org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment.getRegion()Lorg/apache/hadoop/hbase/regionserver/Region;
	at
org.apache.kylin.storage.hbase.cube.v2.coprocessor.endpoint.CubeVisitService.visitCube(CubeVisitService.java:158)
	at
org.apache.kylin.storage.hbase.cube.v2.coprocessor.endpoint.generated.CubeVisitProtos$CubeVisitService.callMethod(CubeVisitProtos.java:3800)
	at
org.apache.hadoop.hbase.regionserver.HRegion.execService(HRegion.java:6138)
	at
org.apache.hadoop.hbase.regionserver.RSRpcServices.execServiceOnRegion(RSRpcServices.java:1688)
	at
org.apache.hadoop.hbase.regionserver.RSRpcServices.execService(RSRpcServices.java:1670)
	at
org.apache.hadoop.hbase.protobuf.generated.ClientProtos$ClientService$2.callBlockingMethod(ClientProtos.java:31309)
	at org.apache.hadoop.hbase.ipc.RpcServer.call(RpcServer.java:2031)
	... 4 more

	at sun.reflect.NativeConstructorAccessorImpl.newInstance0(Native Method)
	at
sun.reflect.NativeConstructorAccessorImpl.newInstance(NativeConstructorAccessorImpl.java:57)
	at
sun.reflect.DelegatingConstructorAccessorImpl.newInstance(DelegatingConstructorAccessorImpl.java:45)
	at java.lang.reflect.Constructor.newInstance(Constructor.java:526)
	at
org.apache.hadoop.ipc.RemoteException.instantiateException(RemoteException.java:106)
	at
org.apache.hadoop.ipc.RemoteException.unwrapRemoteException(RemoteException.java:95)
	at
org.apache.hadoop.hbase.protobuf.ProtobufUtil.getRemoteException(ProtobufUtil.java:313)
	at
org.apache.hadoop.hbase.protobuf.ProtobufUtil.execService(ProtobufUtil.java:1609)
	at
org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel$1.call(RegionCoprocessorRpcChannel.java:92)
	at
org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel$1.call(RegionCoprocessorRpcChannel.java:89)
	at
org.apache.hadoop.hbase.client.RpcRetryingCaller.callWithRetries(RpcRetryingCaller.java:126)
	at
org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel.callExecService(RegionCoprocessorRpcChannel.java:95)
	at
org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel.callMethod(CoprocessorRpcChannel.java:56)
	at
org.apache.kylin.storage.hbase.cube.v2.coprocessor.endpoint.generated.CubeVisitProtos$CubeVisitService$Stub.visitCube(CubeVisitProtos.java:3861)
	at
org.apache.kylin.storage.hbase.cube.v2.CubeHBaseEndpointRPC$2.call(CubeHBaseEndpointRPC.java:362)
	at
org.apache.kylin.storage.hbase.cube.v2.CubeHBaseEndpointRPC$2.call(CubeHBaseEndpointRPC.java:358)
	at org.apache.hadoop.hbase.client.HTable$16.call(HTable.java:1720)
	... 4 more
Caused by:
org.apache.hadoop.hbase.ipc.RemoteWithExtrasException(org.apache.hadoop.hbase.DoNotRetryIOException):
org.apache.hadoop.hbase.DoNotRetryIOException: java.lang.NoSuchMethodError:
org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment.getRegion()Lorg/apache/hadoop/hbase/regionserver/Region;
	at org.apache.hadoop.hbase.ipc.RpcServer.call(RpcServer.java:2062)
	at org.apache.hadoop.hbase.ipc.CallRunner.run(CallRunner.java:107)
	at
org.apache.hadoop.hbase.ipc.RpcExecutor.consumerLoop(RpcExecutor.java:130)
	at org.apache.hadoop.hbase.ipc.RpcExecutor$1.run(RpcExecutor.java:107)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.NoSuchMethodError:
org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment.getRegion()Lorg/apache/hadoop/hbase/regionserver/Region;
	at
org.apache.kylin.storage.hbase.cube.v2.coprocessor.endpoint.CubeVisitService.visitCube(CubeVisitService.java:158)
	at
org.apache.kylin.storage.hbase.cube.v2.coprocessor.endpoint.generated.CubeVisitProtos$CubeVisitService.callMethod(CubeVisitProtos.java:3800)
	at
org.apache.hadoop.hbase.regionserver.HRegion.execService(HRegion.java:6138)
	at
org.apache.hadoop.hbase.regionserver.RSRpcServices.execServiceOnRegion(RSRpcServices.java:1688)
	at
org.apache.hadoop.hbase.regionserver.RSRpcServices.execService(RSRpcServices.java:1670)
	at
org.apache.hadoop.hbase.protobuf.generated.ClientProtos$ClientService$2.callBlockingMethod(ClientProtos.java:31309)
	at org.apache.hadoop.hbase.ipc.RpcServer.call(RpcServer.java:2031)
	... 4 more

	at org.apache.hadoop.hbase.ipc.RpcClientImpl.call(RpcClientImpl.java:1199)
	at
org.apache.hadoop.hbase.ipc.AbstractRpcClient.callBlockingMethod(AbstractRpcClient.java:216)
	at
org.apache.hadoop.hbase.ipc.AbstractRpcClient$BlockingRpcChannelImplementation.callBlockingMethod(AbstractRpcClient.java:300)
	at
org.apache.hadoop.hbase.protobuf.generated.ClientProtos$ClientService$BlockingStub.execService(ClientProtos.java:31775)
	at
org.apache.hadoop.hbase.protobuf.ProtobufUtil.execService(ProtobufUtil.java:1605)
	... 13 more
2016-05-03 15:39:32,588 INFO  [pool-4-thread-1]
threadpool.DefaultScheduler:106 : Job Fetcher: 0 running, 0 actual running,
0 ready, 11 others

--
View this message in context: http://apache-kylin.74782.x6.nabble.com/Re-My-kylin-cube-build-successfully-but-when-query-I-meet-thisexception-tp4349p4350.html
Sent from the Apache Kylin mailing list archive at Nabble.com.