You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kylin.apache.org by li...@apache.org on 2015/05/12 03:59:32 UTC

[01/14] incubator-kylin git commit: code cleaning

Repository: incubator-kylin
Updated Branches:
  refs/heads/master bad1b867e -> 124121764


code cleaning


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/5db5700e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/5db5700e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/5db5700e

Branch: refs/heads/master
Commit: 5db5700ea1dafad26e92b4c41866247b66c2e36c
Parents: bad1b86
Author: honma <ho...@ebay.com>
Authored: Tue Mar 24 15:50:31 2015 +0800
Committer: honma <ho...@ebay.com>
Committed: Mon Apr 27 10:36:22 2015 +0800

----------------------------------------------------------------------
 .../kylin/common/restclient/Broadcaster.java    |  8 +++---
 .../kylin/common/restclient/RestClient.java     | 16 ++++++------
 .../org/apache/kylin/common/util/BasicTest.java | 19 ++++++++++++++
 .../java/org/apache/kylin/cube/CubeManager.java |  2 +-
 .../kylin/metadata/project/ProjectInstance.java |  4 +++
 .../kylin/metadata/project/ProjectL2Cache.java  | 16 ++++++------
 .../kylin/metadata/project/ProjectManager.java  |  6 +----
 .../kylin/rest/controller/CacheController.java  | 26 +++++++++++---------
 .../endpoint/EndpointTupleIterator.java         |  1 -
 9 files changed, 60 insertions(+), 38 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/common/src/main/java/org/apache/kylin/common/restclient/Broadcaster.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/kylin/common/restclient/Broadcaster.java b/common/src/main/java/org/apache/kylin/common/restclient/Broadcaster.java
index 4523431..f591b11 100644
--- a/common/src/main/java/org/apache/kylin/common/restclient/Broadcaster.java
+++ b/common/src/main/java/org/apache/kylin/common/restclient/Broadcaster.java
@@ -43,7 +43,7 @@ public class Broadcaster {
 
     private static final Logger logger = LoggerFactory.getLogger(Broadcaster.class);
 
-    private BlockingDeque<BroadcastEvent> broadcaseEvents = new LinkedBlockingDeque<>();
+    private BlockingDeque<BroadcastEvent> broadcastEvents = new LinkedBlockingDeque<>();
 
     private AtomicLong counter = new AtomicLong();
 
@@ -57,7 +57,7 @@ public class Broadcaster {
             public void run() {
                 final String[] nodes = KylinConfig.getInstanceFromEnv().getRestServers();
                 if (nodes == null || nodes.length < 1) {//TODO if the node count is greater than 1, it means it is a cluster
-                    logger.info("There is no available rest server; check the 'kylin.rest.servers' config");
+                    logger.warn("There is no available rest server; check the 'kylin.rest.servers' config");
                     return;
                 }
                 final List<RestClient> restClients = Lists.newArrayList();
@@ -67,7 +67,7 @@ public class Broadcaster {
                 final ExecutorService wipingCachePool = Executors.newFixedThreadPool(restClients.size());
                 while (true) {
                     try {
-                        final BroadcastEvent broadcastEvent = broadcaseEvents.takeFirst();
+                        final BroadcastEvent broadcastEvent = broadcastEvents.takeFirst();
                         logger.info("new broadcast event:" + broadcastEvent);
                         for (final RestClient restClient : restClients) {
                             wipingCachePool.execute(new Runnable() {
@@ -102,7 +102,7 @@ public class Broadcaster {
     public void queue(String type, String action, String key) {
         try {
             counter.incrementAndGet();
-            broadcaseEvents.putFirst(new BroadcastEvent(type, action, key));
+            broadcastEvents.putFirst(new BroadcastEvent(type, action, key));
         } catch (Exception e) {
             counter.decrementAndGet();
             logger.error("error putting BroadcastEvent", e);

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/common/src/main/java/org/apache/kylin/common/restclient/RestClient.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/kylin/common/restclient/RestClient.java b/common/src/main/java/org/apache/kylin/common/restclient/RestClient.java
index b81218d..22e5c0e 100644
--- a/common/src/main/java/org/apache/kylin/common/restclient/RestClient.java
+++ b/common/src/main/java/org/apache/kylin/common/restclient/RestClient.java
@@ -89,11 +89,11 @@ public class RestClient {
 
     public void wipeCache(String type, String action, String name) throws IOException {
         String url = baseUrl + "/cache/" + type + "/" + name + "/" + action;
-        HttpMethod get = new PutMethod(url);
+        HttpMethod request = new PutMethod(url);
 
         try {
-            int code = client.executeMethod(get);
-            String msg = Bytes.toString(get.getResponseBody());
+            int code = client.executeMethod(request);
+            String msg = Bytes.toString(request.getResponseBody());
 
             if (code != 200)
                 throw new IOException("Invalid response " + code + " with cache wipe url " + url + "\n" + msg);
@@ -101,16 +101,16 @@ public class RestClient {
         } catch (HttpException ex) {
             throw new IOException(ex);
         } finally {
-            get.releaseConnection();
+            request.releaseConnection();
         }
     }
 
     public String getKylinProperties() throws IOException {
         String url = baseUrl + "/admin/config";
-        HttpMethod get = new GetMethod(url);
+        HttpMethod request = new GetMethod(url);
         try {
-            int code = client.executeMethod(get);
-            String msg = Bytes.toString(get.getResponseBody());
+            int code = client.executeMethod(request);
+            String msg = Bytes.toString(request.getResponseBody());
             JSONObject obj = new JSONObject(msg);
             msg = obj.getString("config");
 
@@ -122,7 +122,7 @@ public class RestClient {
         } catch (JSONException e) {
             throw new IOException("Error when parsing json response from REST");
         } finally {
-            get.releaseConnection();
+            request.releaseConnection();
         }
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/common/src/test/java/org/apache/kylin/common/util/BasicTest.java
----------------------------------------------------------------------
diff --git a/common/src/test/java/org/apache/kylin/common/util/BasicTest.java b/common/src/test/java/org/apache/kylin/common/util/BasicTest.java
index 1fe9dfd..7a8cf1c 100644
--- a/common/src/test/java/org/apache/kylin/common/util/BasicTest.java
+++ b/common/src/test/java/org/apache/kylin/common/util/BasicTest.java
@@ -21,7 +21,12 @@ package org.apache.kylin.common.util;
 import java.io.File;
 import java.io.IOException;
 import java.nio.ByteBuffer;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Executors;
 
+import com.google.common.util.concurrent.Futures;
+import com.google.common.util.concurrent.ListenableFuture;
+import com.google.common.util.concurrent.MoreExecutors;
 import org.apache.commons.configuration.ConfigurationException;
 import org.junit.Ignore;
 import org.junit.Test;
@@ -59,6 +64,20 @@ public class BasicTest {
     @Test
     @Ignore("convenient trial tool for dev")
     public void test1() throws Exception {
+        ExecutorService executorService = Executors.newFixedThreadPool(10);
+        ListenableFuture futureTask = MoreExecutors.listeningDecorator(executorService).submit(new Runnable() {
+            @Override
+            public void run() {
+                
+            }
+        });
+        futureTask.addListener(new Runnable() {
+            @Override
+            public void run() {
+
+            }
+        }, executorService);
+
     }
 
     @Test

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/cube/src/main/java/org/apache/kylin/cube/CubeManager.java
----------------------------------------------------------------------
diff --git a/cube/src/main/java/org/apache/kylin/cube/CubeManager.java b/cube/src/main/java/org/apache/kylin/cube/CubeManager.java
index 75f984c..a2ceb84 100644
--- a/cube/src/main/java/org/apache/kylin/cube/CubeManager.java
+++ b/cube/src/main/java/org/apache/kylin/cube/CubeManager.java
@@ -609,7 +609,7 @@ public class CubeManager implements IRealizationProvider {
     private synchronized CubeInstance loadCubeInstance(String path) throws IOException {
         ResourceStore store = getStore();
 
-        CubeInstance cubeInstance = null;
+        CubeInstance cubeInstance;
         try {
             cubeInstance = store.getResource(path, CubeInstance.class, CUBE_SERIALIZER);
             cubeInstance.setConfig(config);

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectInstance.java
----------------------------------------------------------------------
diff --git a/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectInstance.java b/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectInstance.java
index 096d2ac..6da490d 100644
--- a/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectInstance.java
+++ b/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectInstance.java
@@ -25,6 +25,7 @@ import com.google.common.base.Predicate;
 import com.google.common.collect.ImmutableList;
 import com.google.common.collect.Iterables;
 import com.google.common.collect.Lists;
+import org.apache.commons.lang3.StringUtils;
 import org.apache.kylin.common.persistence.ResourceStore;
 import org.apache.kylin.common.persistence.RootPersistentEntity;
 import org.apache.kylin.metadata.realization.RealizationType;
@@ -241,6 +242,9 @@ public class ProjectInstance extends RootPersistentEntity {
 
         if (tables == null)
             tables = new TreeSet<String>();
+
+        if (StringUtils.isBlank(this.name))
+            throw new IllegalStateException("Project name must not be blank");
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectL2Cache.java
----------------------------------------------------------------------
diff --git a/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectL2Cache.java b/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectL2Cache.java
index d936d08..10c4472 100644
--- a/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectL2Cache.java
+++ b/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectL2Cache.java
@@ -18,9 +18,11 @@
 
 package org.apache.kylin.metadata.project;
 
-import com.google.common.collect.Lists;
-import com.google.common.collect.Maps;
-import com.google.common.collect.Sets;
+import java.util.Collections;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
 import org.apache.kylin.metadata.MetadataManager;
 import org.apache.kylin.metadata.model.*;
 import org.apache.kylin.metadata.realization.IRealization;
@@ -28,10 +30,9 @@ import org.apache.kylin.metadata.realization.RealizationRegistry;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import java.util.Collections;
-import java.util.List;
-import java.util.Map;
-import java.util.Set;
+import com.google.common.collect.Lists;
+import com.google.common.collect.Maps;
+import com.google.common.collect.Sets;
 
 /**
  * This is a second level cache that is built on top of first level cached objects,
@@ -89,6 +90,7 @@ class ProjectL2Cache {
         if (tableCache == null)
             return false;
 
+
         for (ColumnDesc colDesc : tableCache.exposedColumns) {
             if (colDesc.getName().equals(col))
                 return true;

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectManager.java
----------------------------------------------------------------------
diff --git a/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectManager.java b/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectManager.java
index 33d0867..ce93241 100644
--- a/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectManager.java
+++ b/metadata/src/main/java/org/apache/kylin/metadata/project/ProjectManager.java
@@ -25,7 +25,6 @@ import java.util.List;
 import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 
-import org.apache.commons.lang3.StringUtils;
 import org.apache.kylin.metadata.model.ColumnDesc;
 import org.apache.kylin.metadata.model.MeasureDesc;
 import org.apache.kylin.metadata.model.TableDesc;
@@ -124,12 +123,9 @@ public class ProjectManager {
 
         projectInstance.init();
 
-        if (StringUtils.isBlank(projectInstance.getName()))
-            throw new IllegalStateException("Project name must not be blank");
-
         projectMap.putLocal(projectInstance.getName(), projectInstance);
-
         clearL2Cache();
+
         return projectInstance;
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/server/src/main/java/org/apache/kylin/rest/controller/CacheController.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/kylin/rest/controller/CacheController.java b/server/src/main/java/org/apache/kylin/rest/controller/CacheController.java
index 42f5ad8..912d5bc 100644
--- a/server/src/main/java/org/apache/kylin/rest/controller/CacheController.java
+++ b/server/src/main/java/org/apache/kylin/rest/controller/CacheController.java
@@ -54,23 +54,25 @@ public class CacheController extends BasicController {
      * @return if the action success
      * @throws IOException
      */
-    @RequestMapping(value = "/{type}/{name}/{event}", method = {RequestMethod.PUT})
+    @RequestMapping(value = "/{type}/{name}/{event}", method = { RequestMethod.PUT })
     @ResponseBody
     public void wipeCache(@PathVariable String type, @PathVariable String event, @PathVariable String name) throws IOException {
+
         Broadcaster.TYPE wipeType = Broadcaster.TYPE.getType(type);
         EVENT wipeEvent = Broadcaster.EVENT.getEvent(event);
-        final String log = "wipe cache type: " + wipeType + " event:" + wipeEvent + " name:" + name;
-        logger.info(log);
+
+        logger.info("wipe cache type: " + wipeType + " event:" + wipeEvent + " name:" + name);
+
         switch (wipeEvent) {
-            case CREATE:
-            case UPDATE:
-                cacheService.rebuildCache(wipeType, name);
-                break;
-            case DROP:
-                cacheService.removeCache(wipeType, name);
-                break;
-            default:
-                throw new RuntimeException("invalid type:" + wipeEvent);
+        case CREATE:
+        case UPDATE:
+            cacheService.rebuildCache(wipeType, name);
+            break;
+        case DROP:
+            cacheService.removeCache(wipeType, name);
+            break;
+        default:
+            throw new RuntimeException("invalid type:" + wipeEvent);
         }
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/5db5700e/storage/src/main/java/org/apache/kylin/storage/hbase/coprocessor/endpoint/EndpointTupleIterator.java
----------------------------------------------------------------------
diff --git a/storage/src/main/java/org/apache/kylin/storage/hbase/coprocessor/endpoint/EndpointTupleIterator.java b/storage/src/main/java/org/apache/kylin/storage/hbase/coprocessor/endpoint/EndpointTupleIterator.java
index 5bf22e7..8b4d8cf 100644
--- a/storage/src/main/java/org/apache/kylin/storage/hbase/coprocessor/endpoint/EndpointTupleIterator.java
+++ b/storage/src/main/java/org/apache/kylin/storage/hbase/coprocessor/endpoint/EndpointTupleIterator.java
@@ -54,7 +54,6 @@ import org.apache.kylin.storage.hbase.coprocessor.CoprocessorFilter;
 import org.apache.kylin.metadata.tuple.ITuple;
 import org.apache.kylin.metadata.tuple.ITupleIterator;
 
-import javax.xml.datatype.DatatypeConfigurationException;
 
 /**
  * Created by Hongbin Ma(Binmahone) on 12/2/14.


[12/14] incubator-kylin git commit: KYLIN-746 test case under server folder are problematic when tested against minicluster

Posted by li...@apache.org.
KYLIN-746 test case under server folder are problematic when tested against minicluster


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/8744f601
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/8744f601
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/8744f601

Branch: refs/heads/master
Commit: 8744f601854682604c03a4e5d3807236aeb766bf
Parents: 60c68c1
Author: honma <ho...@ebay.com>
Authored: Thu Apr 30 15:50:01 2015 +0800
Committer: honma <ho...@ebay.com>
Committed: Thu Apr 30 15:50:01 2015 +0800

----------------------------------------------------------------------
 pom.xml | 52 +++++++++++++++++++++++++++++++++-------------------
 1 file changed, 33 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/8744f601/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index f3a61c8..a775973 100644
--- a/pom.xml
+++ b/pom.xml
@@ -573,9 +573,15 @@
                                 <exclude>**/BuildIIWithEngineTest.java</exclude>
                                 <exclude>**/SampleCubeSetupTest.java</exclude>
                                 <exclude>**/KylinQueryTest.java</exclude>
-                                <exclue>**/SnapshotManagerTest.java</exclue>
-                                <exclue>**/HiveTableReaderTest.java</exclue>
+                                <exclude>**/SnapshotManagerTest.java</exclude>
+                                <exclude>**/HiveTableReaderTest.java</exclude>
                                 <exclude>**/TableControllerTest.java</exclude>
+
+                                <!--test case under server folder are problematic when tested against minicluster-->
+                                <exclude>**/ServiceTestBase.java</exclude>
+                                <exclude>**/JDBCDriverTest.java</exclude>
+                                <exclude>%regex[.*ControllerTest.*]</exclude>
+                                <exclude>%regex[.*ServiceTest.*]</exclude>
                             </excludes>
                             <systemProperties>
                                 <property>
@@ -587,7 +593,7 @@
                                     <value>false</value>
                                 </property>
                             </systemProperties>
-                            <argLine>-Xms1G -Xmx2G -XX:PermSize=128M -XX:MaxPermSize=256M</argLine>
+                            <argLine>-Xms1G -Xmx4G -XX:PermSize=128M -XX:MaxPermSize=512M</argLine>
                         </configuration>
                     </plugin>
 
@@ -602,16 +608,16 @@
             </activation>
             <build>
                 <plugins>
-                	 <plugin>
-    					<groupId>org.apache.maven.plugins</groupId>
-    					<artifactId>maven-compiler-plugin</artifactId>
-    					<version>2.5.1</version>
-    					<configuration>
-      						<fork>true</fork>
-     						<meminitial>1024m</meminitial>
-      						<maxmem>2048m</maxmem>
-    					</configuration>
-  					</plugin>
+                    <plugin>
+                        <groupId>org.apache.maven.plugins</groupId>
+                        <artifactId>maven-compiler-plugin</artifactId>
+                        <version>2.5.1</version>
+                        <configuration>
+                            <fork>true</fork>
+                            <meminitial>1024m</meminitial>
+                            <maxmem>2048m</maxmem>
+                        </configuration>
+                    </plugin>
                     <plugin>
                         <groupId>org.apache.maven.plugins</groupId>
                         <artifactId>maven-surefire-plugin</artifactId>
@@ -661,9 +667,16 @@
                                 <exclude>**/BuildIIWithEngineTest.java</exclude>
                                 <exclude>**/SampleCubeSetupTest.java</exclude>
                                 <exclude>**/KylinQueryTest.java</exclude>
-                                <exclue>**/SnapshotManagerTest.java</exclue>
-                                <exclue>**/HiveTableReaderTest.java</exclue>
+                                <exclude>**/SnapshotManagerTest.java</exclude>
+                                <exclude>**/HiveTableReaderTest.java</exclude>
                                 <exclude>**/TableControllerTest.java</exclude>
+
+                                <!--test case under server folder are problematic when tested against minicluster-->
+                                <exclude>**/ServiceTestBase.java</exclude>
+                                <exclude>**/JDBCDriverTest.java</exclude>
+                                <exclude>%regex[.*ControllerTest.*]</exclude>
+                                <exclude>%regex[.*ServiceTest.*]</exclude>
+
                             </excludes>
                             <systemProperties>
                                 <property>
@@ -675,7 +688,7 @@
                                     <value>false</value>
                                 </property>
                             </systemProperties>
-                            <argLine>-Xms1G -Xmx2G -XX:PermSize=128M -XX:MaxPermSize=256M</argLine>
+                            <argLine>-Xms1G -Xmx4G -XX:PermSize=128M -XX:MaxPermSize=512M</argLine>
                         </configuration>
                     </plugin>
                     <!-- Apache-RAT checks for files without headers.
@@ -714,16 +727,17 @@
                                 <!-- json configuration file-->
                                 <exclude>webapp/.bowerrc</exclude>
                                 <exclude>webapp/.jshintrc</exclude>
-                                <!-- generated dict files -->                               
+                                <!-- generated dict files -->
                                 <exclude>dictionary/metastore_db/**</exclude>
-                                
+
                                 <!-- MIT license -->
                                 <exclude>webapp/app/css/AdminLTE-fonts.css</exclude>
                                 <exclude>webapp/app/css/AdminLTE.css</exclude>
 
                                 <!-- jdbc log -->
                                 <exclude>jdbc/kylin_jdbc.*</exclude>
-                              	
+                                <exclude>jdbc/kylin_jdbc.log.*</exclude>
+
                             </excludes>
                         </configuration>
                         <executions>


[05/14] incubator-kylin git commit: KYLIN-715 remove license from test data

Posted by li...@apache.org.
KYLIN-715 remove license from test data


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/d0d257a0
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/d0d257a0
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/d0d257a0

Branch: refs/heads/master
Commit: d0d257a01d63c8839b1f840f719ac0a1a86de5f5
Parents: f565e7d
Author: qianhao.zhou <qi...@ebay.com>
Authored: Mon Apr 27 19:30:36 2015 +0800
Committer: qianhao.zhou <qi...@ebay.com>
Committed: Mon Apr 27 19:30:36 2015 +0800

----------------------------------------------------------------------
 query/pom.xml                                   | 69 ++++++++++++++++++++
 query/src/test/resources/query/sql/.gitignore   | 20 ------
 .../resources/query/sql_dynamic/query01.dat     | 18 -----
 .../resources/query/sql_dynamic/query02.dat     | 18 -----
 .../query/sql_verifyCount/query04.sql.expected  | 18 -----
 .../query/sql_verifyCount/query05.sql.expected  | 18 -----
 .../query/sql_verifyCount/query06.sql.expected  | 18 -----
 .../query/sql_verifyCount/query07.sql.expected  | 18 -----
 8 files changed, 69 insertions(+), 128 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/pom.xml
----------------------------------------------------------------------
diff --git a/query/pom.xml b/query/pom.xml
index 6cec58b..030482b 100644
--- a/query/pom.xml
+++ b/query/pom.xml
@@ -222,4 +222,73 @@
         </plugins>
     </build>
 
+    <profiles>
+        <profile>
+            <!-- This profile adds/overrides few features of the 'apache-release'
+                 profile in the parent pom. -->
+            <id>apache-release</id>
+            <build>
+                <plugins>
+                    <!-- Apache-RAT checks for files without headers.
+                         If run on a messy developer's sandbox, it will fail.
+                         This serves as a reminder to only build a release in a clean
+                         sandbox! -->
+                    <plugin>
+                        <groupId>org.apache.rat</groupId>
+                        <artifactId>apache-rat-plugin</artifactId>
+                        <configuration>
+                            <numUnapprovedLicenses>0</numUnapprovedLicenses>
+                            <excludes>
+                                <!-- test data -->
+                                <exclude>src/test/**/*.dat</exclude>
+                                <exclude>src/test/**/*.expected</exclude>
+                            </excludes>
+                        </configuration>
+                        <executions>
+                            <execution>
+                                <phase>verify</phase>
+                                <goals>
+                                    <goal>check</goal>
+                                </goals>
+                            </execution>
+                        </executions>
+                        <dependencies>
+                            <dependency>
+                                <groupId>org.apache.maven.doxia</groupId>
+                                <artifactId>doxia-core</artifactId>
+                                <version>1.6</version>
+                                <exclusions>
+                                    <exclusion>
+                                        <groupId>xerces</groupId>
+                                        <artifactId>xercesImpl</artifactId>
+                                    </exclusion>
+                                </exclusions>
+                            </dependency>
+                        </dependencies>
+                    </plugin>
+                    <plugin>
+                        <groupId>net.ju-n.maven.plugins</groupId>
+                        <artifactId>checksum-maven-plugin</artifactId>
+                        <version>1.2</version>
+                        <executions>
+                            <execution>
+                                <goals>
+                                    <goal>artifacts</goal>
+                                </goals>
+                            </execution>
+                        </executions>
+                        <configuration>
+                            <algorithms>
+                                <algorithm>MD5</algorithm>
+                                <algorithm>SHA-1</algorithm>
+                            </algorithms>
+                            <failOnError>false</failOnError>
+                        </configuration>
+                    </plugin>
+                </plugins>
+            </build>
+        </profile>
+    </profiles>
+
+
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/src/test/resources/query/sql/.gitignore
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql/.gitignore b/query/src/test/resources/query/sql/.gitignore
deleted file mode 100644
index a2e3507..0000000
--- a/query/src/test/resources/query/sql/.gitignore
+++ /dev/null
@@ -1,20 +0,0 @@
---
--- 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.
---
-
-/sample.txt
-/0000.sql

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/src/test/resources/query/sql_dynamic/query01.dat
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql_dynamic/query01.dat b/query/src/test/resources/query/sql_dynamic/query01.dat
index 0f85294..a72c741 100644
--- a/query/src/test/resources/query/sql_dynamic/query01.dat
+++ b/query/src/test/resources/query/sql_dynamic/query01.dat
@@ -1,20 +1,2 @@
---
--- 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.
---
-
 FP-GTC
 Collectibles

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/src/test/resources/query/sql_dynamic/query02.dat
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql_dynamic/query02.dat b/query/src/test/resources/query/sql_dynamic/query02.dat
index 0f85294..a72c741 100644
--- a/query/src/test/resources/query/sql_dynamic/query02.dat
+++ b/query/src/test/resources/query/sql_dynamic/query02.dat
@@ -1,20 +1,2 @@
---
--- 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.
---
-
 FP-GTC
 Collectibles

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/src/test/resources/query/sql_verifyCount/query04.sql.expected
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql_verifyCount/query04.sql.expected b/query/src/test/resources/query/sql_verifyCount/query04.sql.expected
index 84a267e..29d6383 100644
--- a/query/src/test/resources/query/sql_verifyCount/query04.sql.expected
+++ b/query/src/test/resources/query/sql_verifyCount/query04.sql.expected
@@ -1,19 +1 @@
---
--- 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.
---
-
 100

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/src/test/resources/query/sql_verifyCount/query05.sql.expected
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql_verifyCount/query05.sql.expected b/query/src/test/resources/query/sql_verifyCount/query05.sql.expected
index 84a267e..29d6383 100644
--- a/query/src/test/resources/query/sql_verifyCount/query05.sql.expected
+++ b/query/src/test/resources/query/sql_verifyCount/query05.sql.expected
@@ -1,19 +1 @@
---
--- 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.
---
-
 100

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/src/test/resources/query/sql_verifyCount/query06.sql.expected
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql_verifyCount/query06.sql.expected b/query/src/test/resources/query/sql_verifyCount/query06.sql.expected
index 84a267e..29d6383 100644
--- a/query/src/test/resources/query/sql_verifyCount/query06.sql.expected
+++ b/query/src/test/resources/query/sql_verifyCount/query06.sql.expected
@@ -1,19 +1 @@
---
--- 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.
---
-
 100

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/d0d257a0/query/src/test/resources/query/sql_verifyCount/query07.sql.expected
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql_verifyCount/query07.sql.expected b/query/src/test/resources/query/sql_verifyCount/query07.sql.expected
index 84a267e..29d6383 100644
--- a/query/src/test/resources/query/sql_verifyCount/query07.sql.expected
+++ b/query/src/test/resources/query/sql_verifyCount/query07.sql.expected
@@ -1,19 +1 @@
---
--- 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.
---
-
 100


[10/14] incubator-kylin git commit: KYLIN-739, fix test case

Posted by li...@apache.org.
KYLIN-739, fix test case


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/7166c0aa
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/7166c0aa
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/7166c0aa

Branch: refs/heads/master
Commit: 7166c0aa8ac9efb041abd4407565acaa8775ba76
Parents: 9c25a3d
Author: Li, Yang <ya...@ebay.com>
Authored: Wed Apr 29 11:19:15 2015 +0800
Committer: Li, Yang <ya...@ebay.com>
Committed: Wed Apr 29 11:19:15 2015 +0800

----------------------------------------------------------------------
 query/src/test/resources/query/sql/query79.sql | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/7166c0aa/query/src/test/resources/query/sql/query79.sql
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql/query79.sql b/query/src/test/resources/query/sql/query79.sql
index d89b14f..76b7928 100644
--- a/query/src/test/resources/query/sql/query79.sql
+++ b/query/src/test/resources/query/sql/query79.sql
@@ -16,4 +16,4 @@
 -- limitations under the License.
 --
 
-select max(cal_dt) from test_kylin_fact
+select max(cal_dt) as cnt from test_kylin_fact


[07/14] incubator-kylin git commit: KYLIN-669 add AdminLTE MIT License in LICENSE file

Posted by li...@apache.org.
KYLIN-669 add AdminLTE MIT License in LICENSE file


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/0c8d7933
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/0c8d7933
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/0c8d7933

Branch: refs/heads/master
Commit: 0c8d7933df707e607537018c6c80a67523c74182
Parents: f22b81c
Author: lukehan <lu...@apache.org>
Authored: Tue Apr 28 16:18:04 2015 +0800
Committer: lukehan <lu...@apache.org>
Committed: Tue Apr 28 16:18:04 2015 +0800

----------------------------------------------------------------------
 LICENSE | 18 ++++++++++++++++++
 1 file changed, 18 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/0c8d7933/LICENSE
----------------------------------------------------------------------
diff --git a/LICENSE b/LICENSE
index 29dc295..d15d498 100644
--- a/LICENSE
+++ b/LICENSE
@@ -52,3 +52,21 @@ You may add Your own copyright statement to Your modifications and may provide a
 
 END OF TERMS AND CONDITIONS
 
+
+
+
+==============================================================================
+Apache Kylin (incubating) Subcomponents:
+
+The Apache Kylin project contains subcomponents with separate copyright
+notices and license terms. Your use of the source code for the these
+subcomponents is subject to the terms and conditions of the following
+licenses.
+
+
+==============================================================================
+For AdminLTE:
+==============================================================================
+This product bundles AdminLTE, which is available under a
+"MIT" license.  For details, see
+https://github.com/almasaeed2010/AdminLTE/blob/master/LICENSE.
\ No newline at end of file


[03/14] incubator-kylin git commit: KYLIN-669 update pom for OOM issue

Posted by li...@apache.org.
KYLIN-669 update pom for OOM issue


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/f565e7d2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/f565e7d2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/f565e7d2

Branch: refs/heads/master
Commit: f565e7d224abe2c1718173d51fac8e5d6089ce1a
Parents: b0ab9c0
Author: lukehan <lu...@apache.org>
Authored: Mon Apr 27 10:50:20 2015 +0800
Committer: lukehan <lu...@apache.org>
Committed: Mon Apr 27 10:50:27 2015 +0800

----------------------------------------------------------------------
 dictionary/pom.xml | 67 -------------------------------------------------
 pom.xml            |  9 ++++++-
 2 files changed, 8 insertions(+), 68 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/f565e7d2/dictionary/pom.xml
----------------------------------------------------------------------
diff --git a/dictionary/pom.xml b/dictionary/pom.xml
index 266d5e7..524a52f 100644
--- a/dictionary/pom.xml
+++ b/dictionary/pom.xml
@@ -125,71 +125,4 @@
         </dependency>
     </dependencies>
 
-    <profiles>
-        <profile>
-            <!-- This profile adds/overrides few features of the 'apache-release'
-                 profile in the parent pom. -->
-            <id>apache-release</id>
-            <build>
-                <plugins>
-                    <!-- Apache-RAT checks for files without headers.
-                         If run on a messy developer's sandbox, it will fail.
-                         This serves as a reminder to only build a release in a clean
-                         sandbox! -->
-                    <plugin>
-                        <groupId>org.apache.rat</groupId>
-                        <artifactId>apache-rat-plugin</artifactId>
-                        <configuration>
-                            <numUnapprovedLicenses>0</numUnapprovedLicenses>
-                            <excludes>
-                                <!-- test data -->
-                                <exclude>src/test/resources/dict/eng_com.dic</exclude>
-                            </excludes>
-                        </configuration>
-                        <executions>
-                            <execution>
-                                <phase>verify</phase>
-                                <goals>
-                                    <goal>check</goal>
-                                </goals>
-                            </execution>
-                        </executions>
-                        <dependencies>
-                            <dependency>
-                                <groupId>org.apache.maven.doxia</groupId>
-                                <artifactId>doxia-core</artifactId>
-                                <version>1.6</version>
-                                <exclusions>
-                                    <exclusion>
-                                        <groupId>xerces</groupId>
-                                        <artifactId>xercesImpl</artifactId>
-                                    </exclusion>
-                                </exclusions>
-                            </dependency>
-                        </dependencies>
-                    </plugin>
-                    <plugin>
-                        <groupId>net.ju-n.maven.plugins</groupId>
-                        <artifactId>checksum-maven-plugin</artifactId>
-                        <version>1.2</version>
-                        <executions>
-                            <execution>
-                                <goals>
-                                    <goal>artifacts</goal>
-                                </goals>
-                            </execution>
-                        </executions>
-                        <configuration>
-                            <algorithms>
-                                <algorithm>MD5</algorithm>
-                                <algorithm>SHA-1</algorithm>
-                            </algorithms>
-                            <failOnError>false</failOnError>
-                        </configuration>
-                    </plugin>
-                </plugins>
-            </build>
-        </profile>
-    </profiles>
-
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/f565e7d2/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 0c4562f..0ce8848 100644
--- a/pom.xml
+++ b/pom.xml
@@ -609,7 +609,7 @@
     					<configuration>
       						<fork>true</fork>
      						<meminitial>1024m</meminitial>
-      						<maxmem>1024m</maxmem>
+      						<maxmem>2048m</maxmem>
     					</configuration>
   					</plugin>
                     <plugin>
@@ -666,8 +666,10 @@
                                 <exclude>**/*.md</exclude>
                                 <!-- binary files -->
                                 <exclude>**/*.dict</exclude>
+                                <exclude>**/*.dic</exclude>
                                 <exclude>**/*.snapshot</exclude>
                                 <exclude>**/*.pdf</exclude>
+                                <exclude>**/*.log</exclude>
 
                                 <!-- generated files -->
                                 <exclude>**/target/**</exclude>
@@ -684,10 +686,15 @@
                                 <!-- json configuration file-->
                                 <exclude>webapp/.bowerrc</exclude>
                                 <exclude>webapp/.jshintrc</exclude>
+                                <!-- generated dict files -->                               
+                                <exclude>dictionary/metastore_db/**</exclude>
+                                
                                 <!-- MIT license -->
                                 <exclude>webapp/app/css/AdminLTE-fonts.css</exclude>
                                 <exclude>webapp/app/css/AdminLTE.css</exclude>
+                              	
                             </excludes>
+                            <argLine>-Xms1G -Xmx2G -XX:PermSize=128M -XX:MaxPermSize=256M</argLine>
                         </configuration>
                         <executions>
                             <execution>


[11/14] incubator-kylin git commit: Fix null value decode issue in mergecuboidmapper

Posted by li...@apache.org.
Fix null value decode issue in mergecuboidmapper


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/60c68c1d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/60c68c1d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/60c68c1d

Branch: refs/heads/master
Commit: 60c68c1d3f773ca7eca4f4deb639f4e97c963e82
Parents: 7166c0a
Author: honma <ho...@ebay.com>
Authored: Mon Apr 27 17:21:14 2015 +0800
Committer: honma <ho...@ebay.com>
Committed: Wed Apr 29 14:01:33 2015 +0800

----------------------------------------------------------------------
 .../src/main/java/org/apache/kylin/dict/Dictionary.java   |  6 ++++--
 .../java/org/apache/kylin/dict/DateStrDictionaryTest.java |  2 +-
 .../java/org/apache/kylin/dict/TrieDictionaryTest.java    |  2 +-
 .../apache/kylin/job/hadoop/cube/MergeCuboidMapper.java   | 10 ++++++++--
 4 files changed, 14 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/60c68c1d/dictionary/src/main/java/org/apache/kylin/dict/Dictionary.java
----------------------------------------------------------------------
diff --git a/dictionary/src/main/java/org/apache/kylin/dict/Dictionary.java b/dictionary/src/main/java/org/apache/kylin/dict/Dictionary.java
index ed6bcb9..6a06ed2 100644
--- a/dictionary/src/main/java/org/apache/kylin/dict/Dictionary.java
+++ b/dictionary/src/main/java/org/apache/kylin/dict/Dictionary.java
@@ -145,13 +145,15 @@ abstract public class Dictionary<T> implements Writable {
      * A lower level API, get byte values from ID, return the number of bytes
      * written. Bypassing the cache layer, this could be significantly slower
      * than getIdFromValue(T value).
-     * 
+     *
+     * @return size of value bytes, 0 if empty string, -1 if null
+     *
      * @throws IllegalArgumentException
      *             if ID is not found in dictionary
      */
     final public int getValueBytesFromId(int id, byte[] returnValue, int offset) {
         if (isNullId(id))
-            return 0;
+            return -1;
         else
             return getValueBytesFromIdImpl(id, returnValue, offset);
     }

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/60c68c1d/dictionary/src/test/java/org/apache/kylin/dict/DateStrDictionaryTest.java
----------------------------------------------------------------------
diff --git a/dictionary/src/test/java/org/apache/kylin/dict/DateStrDictionaryTest.java b/dictionary/src/test/java/org/apache/kylin/dict/DateStrDictionaryTest.java
index f393ead..81db5df 100644
--- a/dictionary/src/test/java/org/apache/kylin/dict/DateStrDictionaryTest.java
+++ b/dictionary/src/test/java/org/apache/kylin/dict/DateStrDictionaryTest.java
@@ -64,7 +64,7 @@ public class DateStrDictionaryTest {
         int nullId = dict.getIdFromValue(null);
         assertNull(dict.getValueFromId(nullId));
         int nullId2 = dict.getIdFromValueBytes(null, 0, 0);
-        assertEquals(dict.getValueBytesFromId(nullId2, null, 0), 0);
+        assertEquals(dict.getValueBytesFromId(nullId2, null, 0), -1);
         assertEquals(nullId, nullId2);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/60c68c1d/dictionary/src/test/java/org/apache/kylin/dict/TrieDictionaryTest.java
----------------------------------------------------------------------
diff --git a/dictionary/src/test/java/org/apache/kylin/dict/TrieDictionaryTest.java b/dictionary/src/test/java/org/apache/kylin/dict/TrieDictionaryTest.java
index fb69a8c..6a8e19d 100644
--- a/dictionary/src/test/java/org/apache/kylin/dict/TrieDictionaryTest.java
+++ b/dictionary/src/test/java/org/apache/kylin/dict/TrieDictionaryTest.java
@@ -274,7 +274,7 @@ public class TrieDictionaryTest {
         int nullId = dict.getIdFromValue(null);
         assertNull(dict.getValueFromId(nullId));
         int nullId2 = dict.getIdFromValueBytes(null, 0, 0);
-        assertEquals(dict.getValueBytesFromId(nullId2, null, 0), 0);
+        assertEquals(dict.getValueBytesFromId(nullId2, null, 0), -1);
         assertEquals(nullId, nullId2);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/60c68c1d/job/src/main/java/org/apache/kylin/job/hadoop/cube/MergeCuboidMapper.java
----------------------------------------------------------------------
diff --git a/job/src/main/java/org/apache/kylin/job/hadoop/cube/MergeCuboidMapper.java b/job/src/main/java/org/apache/kylin/job/hadoop/cube/MergeCuboidMapper.java
index 431f2b7..d0a0d19 100644
--- a/job/src/main/java/org/apache/kylin/job/hadoop/cube/MergeCuboidMapper.java
+++ b/job/src/main/java/org/apache/kylin/job/hadoop/cube/MergeCuboidMapper.java
@@ -162,10 +162,16 @@ public class MergeCuboidMapper extends KylinMapper<Text, Text, Text, Text> {
                 }
 
                 int idInSourceDict = BytesUtil.readUnsigned(splittedByteses[i + 1].value, 0, splittedByteses[i + 1].length);
+                int idInMergedDict;
+
                 int size = sourceDict.getValueBytesFromId(idInSourceDict, newKeyBuf, bufOffset);
-                int idInMergedDict = mergedDict.getIdFromValueBytes(newKeyBuf, bufOffset, size);
-                BytesUtil.writeUnsigned(idInMergedDict, newKeyBuf, bufOffset, mergedDict.getSizeOfId());
+                if (size < 0) {
+                    idInMergedDict = mergedDict.nullId();
+                } else {
+                    idInMergedDict = mergedDict.getIdFromValueBytes(newKeyBuf, bufOffset, size);
+                }
 
+                BytesUtil.writeUnsigned(idInMergedDict, newKeyBuf, bufOffset, mergedDict.getSizeOfId());
                 bufOffset += mergedDict.getSizeOfId();
             } else {
                 // keep as it is


[09/14] incubator-kylin git commit: KYLIN-740, increase scan range merge threshold to 100

Posted by li...@apache.org.
KYLIN-740, increase scan range merge threshold to 100


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/9c25a3d1
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/9c25a3d1
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/9c25a3d1

Branch: refs/heads/master
Commit: 9c25a3d181215d8618090eff1f4e541ff506b130
Parents: 9d67534
Author: Li, Yang <ya...@ebay.com>
Authored: Wed Apr 29 11:13:57 2015 +0800
Committer: Li, Yang <ya...@ebay.com>
Committed: Wed Apr 29 11:13:57 2015 +0800

----------------------------------------------------------------------
 .../java/org/apache/kylin/storage/hbase/CubeStorageEngine.java     | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/9c25a3d1/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
----------------------------------------------------------------------
diff --git a/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java b/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
index cd671ba..3ed8f14 100644
--- a/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
+++ b/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
@@ -63,7 +63,7 @@ public class CubeStorageEngine implements IStorageEngine {
 
     private static final Logger logger = LoggerFactory.getLogger(CubeStorageEngine.class);
 
-    private static final int MERGE_KEYRANGE_THRESHOLD = 7;
+    private static final int MERGE_KEYRANGE_THRESHOLD = 100;
     private static final long MEM_BUDGET_PER_QUERY = 3L * 1024 * 1024 * 1024; // 3G
 
     private final CubeInstance cubeInstance;


[13/14] incubator-kylin git commit: KYLIN-757 Cache wasn't flushed in cluster mode

Posted by li...@apache.org.
KYLIN-757 Cache wasn't flushed in cluster mode

Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/7ee27ad6
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/7ee27ad6
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/7ee27ad6

Branch: refs/heads/master
Commit: 7ee27ad6054bbf966d791d2303ede4d58283aeae
Parents: 8744f60
Author: Shao Feng, Shi <sh...@ebay.com>
Authored: Fri May 8 18:10:29 2015 +0800
Committer: Shao Feng, Shi <sh...@ebay.com>
Committed: Fri May 8 18:10:29 2015 +0800

----------------------------------------------------------------------
 common/src/main/java/org/apache/kylin/common/KylinConfig.java | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/7ee27ad6/common/src/main/java/org/apache/kylin/common/KylinConfig.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/kylin/common/KylinConfig.java b/common/src/main/java/org/apache/kylin/common/KylinConfig.java
index 113afd4..3e3f4a3 100644
--- a/common/src/main/java/org/apache/kylin/common/KylinConfig.java
+++ b/common/src/main/java/org/apache/kylin/common/KylinConfig.java
@@ -490,6 +490,7 @@ public class KylinConfig {
 
     void reloadKylinConfig(InputStream is) {
         PropertiesConfiguration config = new PropertiesConfiguration();
+        config.setListDelimiter((char)0); // disable list delimiter, Kylin will parse and split
         try {
             config.load(is);
         } catch (ConfigurationException e) {


[06/14] incubator-kylin git commit: KYLIN-715 update pom for release issue

Posted by li...@apache.org.
KYLIN-715 update pom for release issue


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/f22b81cf
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/f22b81cf
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/f22b81cf

Branch: refs/heads/master
Commit: f22b81cff4b2a4b6fb1853194dac915a6141f6ca
Parents: d0d257a
Author: lukehan <lu...@apache.org>
Authored: Tue Apr 28 16:17:01 2015 +0800
Committer: lukehan <lu...@apache.org>
Committed: Tue Apr 28 16:17:01 2015 +0800

----------------------------------------------------------------------
 .gitignore | 18 +++++++++++++-----
 pom.xml    | 32 +++++++++++++++++++++++++++++++-
 2 files changed, 44 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/f22b81cf/.gitignore
----------------------------------------------------------------------
diff --git a/.gitignore b/.gitignore
index 08a55a3..62b46f0 100644
--- a/.gitignore
+++ b/.gitignore
@@ -43,6 +43,10 @@ release.properties
 *.jar
 *.war
 *.ear
+*.tgz
+*.tar.gz
+
+
 
 # virtual machine crash logs, see http://www.java.com/en/download/help/error_hotspot.xml
 hs_err_pid*
@@ -54,14 +58,15 @@ hs_err_pid*
 .project
 .idea
 **/*.DS_Store
-target
-logs
 *.jar
 *.releaseBackup
 *.log
+jdbc/kylin_jdbc.log.*
 *.DS_Store
 *.releaseBackup
 
+
+
 # .settings
 org.eclipse.m2e.core.prefs
 org.eclipse.wst.common.component
@@ -71,15 +76,18 @@ server/.settings/.jsdtscope
 server/.settings/org.eclipse.wst.common.project.facet.core.prefs.xml
 server/.settings/org.eclipse.wst.jsdt.ui.superType.container
 server/.settings/org.eclipse.wst.jsdt.ui.superType.name
+
 #web
 webapp/app/WEB-INF/*
 webapp/dist
 webapp/node_modules:
 webapp/CHANGELOG.md
 
-# package file
+# generated files
+target
+logs
+
+# package file and folder
 tomcat
 lib
-*.tgz
-*.tar.gz
 webapp/app/components/*

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/f22b81cf/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 0ce8848..f3a61c8 100644
--- a/pom.xml
+++ b/pom.xml
@@ -650,6 +650,34 @@
             <id>apache-release</id>
             <build>
                 <plugins>
+                    <plugin>
+                        <groupId>org.apache.maven.plugins</groupId>
+                        <artifactId>maven-surefire-plugin</artifactId>
+                        <version>2.16</version>
+                        <configuration>
+                            <reportsDirectory>${project.basedir}/../target/surefire-reports</reportsDirectory>
+                            <excludes>
+                                <exclude>**/BuildCubeWithEngineTest.java</exclude>
+                                <exclude>**/BuildIIWithEngineTest.java</exclude>
+                                <exclude>**/SampleCubeSetupTest.java</exclude>
+                                <exclude>**/KylinQueryTest.java</exclude>
+                                <exclue>**/SnapshotManagerTest.java</exclue>
+                                <exclue>**/HiveTableReaderTest.java</exclue>
+                                <exclude>**/TableControllerTest.java</exclude>
+                            </excludes>
+                            <systemProperties>
+                                <property>
+                                    <name>useSandbox</name>
+                                    <value>false</value>
+                                </property>
+                                <property>
+                                    <name>buildCubeUsingProvidedData</name>
+                                    <value>false</value>
+                                </property>
+                            </systemProperties>
+                            <argLine>-Xms1G -Xmx2G -XX:PermSize=128M -XX:MaxPermSize=256M</argLine>
+                        </configuration>
+                    </plugin>
                     <!-- Apache-RAT checks for files without headers.
                          If run on a messy developer's sandbox, it will fail.
                          This serves as a reminder to only build a release in a clean
@@ -692,9 +720,11 @@
                                 <!-- MIT license -->
                                 <exclude>webapp/app/css/AdminLTE-fonts.css</exclude>
                                 <exclude>webapp/app/css/AdminLTE.css</exclude>
+
+                                <!-- jdbc log -->
+                                <exclude>jdbc/kylin_jdbc.*</exclude>
                               	
                             </excludes>
-                            <argLine>-Xms1G -Xmx2G -XX:PermSize=128M -XX:MaxPermSize=256M</argLine>
                         </configuration>
                         <executions>
                             <execution>


[08/14] incubator-kylin git commit: KYLIN-739, Dimension as metrics does not work with PK-FK derived column

Posted by li...@apache.org.
KYLIN-739, Dimension as metrics does not work with PK-FK derived column


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/9d67534d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/9d67534d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/9d67534d

Branch: refs/heads/master
Commit: 9d67534d25e43cade94b3ebc0a05194292cfd736
Parents: 0c8d793
Author: Li, Yang <ya...@ebay.com>
Authored: Wed Apr 29 10:43:05 2015 +0800
Committer: Li, Yang <ya...@ebay.com>
Committed: Wed Apr 29 10:43:05 2015 +0800

----------------------------------------------------------------------
 .../AdjustForWeeklyMatchedRealization.java       |  1 -
 query/src/test/resources/query/sql/query79.sql   | 19 +++++++++++++++++++
 .../org/apache/kylin/storage/StorageContext.java | 17 +++--------------
 .../kylin/storage/hbase/CubeStorageEngine.java   |  1 -
 4 files changed, 22 insertions(+), 16 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/9d67534d/query/src/main/java/org/apache/kylin/query/routing/RoutingRules/AdjustForWeeklyMatchedRealization.java
----------------------------------------------------------------------
diff --git a/query/src/main/java/org/apache/kylin/query/routing/RoutingRules/AdjustForWeeklyMatchedRealization.java b/query/src/main/java/org/apache/kylin/query/routing/RoutingRules/AdjustForWeeklyMatchedRealization.java
index 7a36cf1..df58944 100644
--- a/query/src/main/java/org/apache/kylin/query/routing/RoutingRules/AdjustForWeeklyMatchedRealization.java
+++ b/query/src/main/java/org/apache/kylin/query/routing/RoutingRules/AdjustForWeeklyMatchedRealization.java
@@ -85,7 +85,6 @@ public class AdjustForWeeklyMatchedRealization extends RoutingRule {
                 if (col != null) {
                     olapContext.metricsColumns.remove(col);
                     olapContext.groupByColumns.add(col);
-                    olapContext.storageContext.addOtherMandatoryColumns(col);
                 }
                 logger.info("Adjust OLAPContext for " + functionDesc);
             }

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/9d67534d/query/src/test/resources/query/sql/query79.sql
----------------------------------------------------------------------
diff --git a/query/src/test/resources/query/sql/query79.sql b/query/src/test/resources/query/sql/query79.sql
new file mode 100644
index 0000000..d89b14f
--- /dev/null
+++ b/query/src/test/resources/query/sql/query79.sql
@@ -0,0 +1,19 @@
+--
+-- 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.
+--
+
+select max(cal_dt) from test_kylin_fact

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/9d67534d/storage/src/main/java/org/apache/kylin/storage/StorageContext.java
----------------------------------------------------------------------
diff --git a/storage/src/main/java/org/apache/kylin/storage/StorageContext.java b/storage/src/main/java/org/apache/kylin/storage/StorageContext.java
index fac99cc..d80e07d 100644
--- a/storage/src/main/java/org/apache/kylin/storage/StorageContext.java
+++ b/storage/src/main/java/org/apache/kylin/storage/StorageContext.java
@@ -19,16 +19,15 @@
 package org.apache.kylin.storage;
 
 import java.util.ArrayList;
-import java.util.HashSet;
 import java.util.List;
-import java.util.Set;
 
-import com.google.common.collect.BiMap;
-import com.google.common.collect.HashBiMap;
 import org.apache.kylin.cube.cuboid.Cuboid;
 import org.apache.kylin.metadata.model.MeasureDesc;
 import org.apache.kylin.metadata.model.TblColRef;
 
+import com.google.common.collect.BiMap;
+import com.google.common.collect.HashBiMap;
+
 /**
  * @author xjiang
  */
@@ -51,7 +50,6 @@ public class StorageContext {
     private BiMap<TblColRef, String> aliasMap;
 
     private boolean exactAggregation;
-    private Set<TblColRef> otherMandatoryColumns;
     private boolean enableLimit;
     private boolean enableCoprocessor;
 
@@ -70,7 +68,6 @@ public class StorageContext {
         this.sortMeasures = new ArrayList<MeasureDesc>();
 
         this.exactAggregation = false;
-        this.otherMandatoryColumns = new HashSet<TblColRef>();
         this.enableLimit = false;
         this.enableCoprocessor = false;
 
@@ -185,14 +182,6 @@ public class StorageContext {
         return this.exactAggregation;
     }
 
-    public void addOtherMandatoryColumns(TblColRef col) {
-        this.otherMandatoryColumns.add(col);
-    }
-
-    public Set<TblColRef> getOtherMandatoryColumns() {
-        return this.otherMandatoryColumns;
-    }
-
     public void enableCoprocessor() {
         this.enableCoprocessor = true;
     }

http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/9d67534d/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
----------------------------------------------------------------------
diff --git a/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java b/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
index 8737e8c..cd671ba 100644
--- a/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
+++ b/storage/src/main/java/org/apache/kylin/storage/hbase/CubeStorageEngine.java
@@ -112,7 +112,6 @@ public class CubeStorageEngine implements IStorageEngine {
         // - columns on non-evaluatable filter have to return
         // - columns on loosened filter (due to derived translation) have to return
         Set<TblColRef> groupsCopD = Sets.newHashSet(groupsD);
-        groupsCopD.addAll(context.getOtherMandatoryColumns()); // TODO: this is tricky, to generalize
         collectNonEvaluable(filter, groupsCopD);
         TupleFilter filterD = translateDerived(filter, groupsCopD);
 


[04/14] incubator-kylin git commit: KYLIN-669 update maven memory setting to avoid OOM exception when run ut

Posted by li...@apache.org.
KYLIN-669 update maven memory setting to avoid OOM exception when run ut


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/b0ab9c07
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/b0ab9c07
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/b0ab9c07

Branch: refs/heads/master
Commit: b0ab9c07ff18f0f07c0e21a8f322a53a70dabf19
Parents: 267c98c
Author: lukehan <lu...@apache.org>
Authored: Sun Apr 26 19:29:08 2015 +0800
Committer: lukehan <lu...@apache.org>
Committed: Mon Apr 27 10:50:27 2015 +0800

----------------------------------------------------------------------
 pom.xml | 10 ++++++++++
 1 file changed, 10 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/b0ab9c07/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index e65bab0..0c4562f 100644
--- a/pom.xml
+++ b/pom.xml
@@ -602,6 +602,16 @@
             </activation>
             <build>
                 <plugins>
+                	 <plugin>
+    					<groupId>org.apache.maven.plugins</groupId>
+    					<artifactId>maven-compiler-plugin</artifactId>
+    					<version>2.5.1</version>
+    					<configuration>
+      						<fork>true</fork>
+     						<meminitial>1024m</meminitial>
+      						<maxmem>1024m</maxmem>
+    					</configuration>
+  					</plugin>
                     <plugin>
                         <groupId>org.apache.maven.plugins</groupId>
                         <artifactId>maven-surefire-plugin</artifactId>


[14/14] incubator-kylin git commit: update document for "Kylin Metadata Store"

Posted by li...@apache.org.
update document for "Kylin Metadata Store"


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/12412176
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/12412176
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/12412176

Branch: refs/heads/master
Commit: 124121764a3eb0652032c8add97f02708aa5fd3a
Parents: 7ee27ad
Author: Li, Yang <ya...@ebay.com>
Authored: Tue May 12 09:55:12 2015 +0800
Committer: Li, Yang <ya...@ebay.com>
Committed: Tue May 12 09:55:12 2015 +0800

----------------------------------------------------------------------
 docs/Operations/Kylin Metadata Store.md | 28 ++++++++++++----------------
 1 file changed, 12 insertions(+), 16 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/12412176/docs/Operations/Kylin Metadata Store.md
----------------------------------------------------------------------
diff --git a/docs/Operations/Kylin Metadata Store.md b/docs/Operations/Kylin Metadata Store.md
index bba3b58..79ec091 100644
--- a/docs/Operations/Kylin Metadata Store.md	
+++ b/docs/Operations/Kylin Metadata Store.md	
@@ -1,31 +1,27 @@
-Kylin organizes all of its metadata(including cube descriptions and instances, projects, inverted index description and instances, jobs, tables and dictionaries) as a hierarchy file system. However, Kylin uses hbase to store it, rather than normal file system. If you check your kylin configuration file(kylin.properties) you will find such a line:
+Kylin organizes all of its metadata (including cube descriptions and instances, projects, inverted index description and instances, jobs, tables and dictionaries) as a hierarchy of files, that are stored in HBase. You can backup and restore these metadata by download to local file system and upload again.
 
-`# The metadata store in hbase`
-`kylin.metadata.url=kylin_metadata@hbase:sandbox.hortonworks.com:2181:/hbase-unsecure`
+Check the `conf/kylin.properties`
 
-This indicates that the metadata will be saved as a htable called `kylin_metadata`. You can scan the htable in hbase shell to check it out.
+	kylin.metadata.url=kylin_metadata@hbase
 
-# Backup Metadata Store
+This indicates that the metadata will be saved as a HTable called `kylin_metadata`. You can scan the HTable in HBase shell.
 
-Sometimes you need to backup the Kylin's Metadata Store from hbase to your disk file system.
-In such cases, assuming you're on the hadoop CLI(or sandbox) where you deployed Kylin, you can use:
+# Backup Metadata Store
 
-	mkdir ~/meta_dump
+Sometimes you want to backup Kylin's metadata. Below command downloads all metadata to local directory `~/meta_dump`.
 
-	hbase  org.apache.hadoop.util.RunJar  ${KYLIN_HOME}/lib/kylin-job-x.x.x-SNAPSHOT-job.jar org.apache.kylin.common.persistence.ResourceTool  copy ${KYLIN_HOME}/conf/kylin.properties ~/meta_dump 
+	hbase  org.apache.hadoop.util.RunJar  ${KYLIN_HOME}/lib/kylin-job-x.x.x-SNAPSHOT-job.jar  org.apache.kylin.common.persistence.ResourceTool  download  ~/meta_dump
 
-to dump your metadata to your local folder ~/meta_dump.
+Add `-Dexclude=/dict,/job_output,/table_snapshot` flag to the command to exclude certain metadata sub-directories.
 
 # Restore Metadata Store
 
-In case you find your metadata store messed up, and you want to restore to a previous backup:
-
-first clean up the metadata store:
+To restore a backup, first clean up the metadata store.
 
-	hbase  org.apache.hadoop.util.RunJar ${KYLIN_HOME}/lib/kylin-job-x.x.x-SNAPSHOT-job.jar org.apache.kylin.common.persistence.ResourceTool  reset  
+	hbase  org.apache.hadoop.util.RunJar  ${KYLIN_HOME}/lib/kylin-job-x.x.x-SNAPSHOT-job.jar  org.apache.kylin.common.persistence.ResourceTool  reset  
 
-then upload the backup metadata in ~/meta_dump to Kylin's metadata store:
+Then upload the backup metadata from local file system.
 
-	hbase  org.apache.hadoop.util.RunJar  ${KYLIN_HOME}/lib/kylin-job-x.x.x-SNAPSHOT-job.jar org.apache.kylin.common.persistence.ResourceTool  copy ~/meta_dump ${KYLIN_HOME}/conf/kylin.properties  
+	hbase  org.apache.hadoop.util.RunJar  ${KYLIN_HOME}/lib/kylin-job-x.x.x-SNAPSHOT-job.jar  org.apache.kylin.common.persistence.ResourceTool  upload  ~/meta_dump
 
 


[02/14] incubator-kylin git commit: add FAQ for AcceptPartialResults

Posted by li...@apache.org.
add FAQ for AcceptPartialResults


Project: http://git-wip-us.apache.org/repos/asf/incubator-kylin/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-kylin/commit/267c98c6
Tree: http://git-wip-us.apache.org/repos/asf/incubator-kylin/tree/267c98c6
Diff: http://git-wip-us.apache.org/repos/asf/incubator-kylin/diff/267c98c6

Branch: refs/heads/master
Commit: 267c98c6992faa05f5a3a04f0d83d98e20dfebc7
Parents: 5db5700
Author: honma <ho...@ebay.com>
Authored: Mon Apr 27 10:40:42 2015 +0800
Committer: honma <ho...@ebay.com>
Committed: Mon Apr 27 10:40:42 2015 +0800

----------------------------------------------------------------------
 docs/MISC/FAQ on Kylin Installation and Usage.md | 9 +++++++++
 1 file changed, 9 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-kylin/blob/267c98c6/docs/MISC/FAQ on Kylin Installation and Usage.md
----------------------------------------------------------------------
diff --git a/docs/MISC/FAQ on Kylin Installation and Usage.md b/docs/MISC/FAQ on Kylin Installation and Usage.md
index a568614..2891cfe 100644
--- a/docs/MISC/FAQ on Kylin Installation and Usage.md	
+++ b/docs/MISC/FAQ on Kylin Installation and Usage.md	
@@ -41,3 +41,12 @@ The cardinality of dimensions is an important measure of cube complexity. The hi
 
 #### What is the difference between Kylin and Druid
 take a look at http://mail-archives.apache.org/mod_mbox/incubator-kylin-dev/201503.mbox/%3Ctencent_0DAD681A15F3B2F2379CADC9%40qq.com%3E
+
+#### Getting wrong result for the query with order by
+By default if you're making queries on the web client, a mode called "AcceptPartialResults" is enabled​, this is a protection mechanism that will only return part of the results to reduce server overhead. Honestly it might hurt the correctness of order by queries. 
+
+If you're seeking 100% correctness, after running the query you will find a notification:
+Note: Current results are partial, please click 'Show All' button to get all results.
+Click the "Show All" button to disable the "AcceptPartialResults" mode, and you'll get a right result.
+
+Notice "AcceptPartialResults" is only enabled by default at web client, you'll not meet such problems if you're using JDBC, ODBC or standard REST API.