[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

classic Classic list List threaded Threaded
25 messages Options
12
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
GitHub user kumarvishal09 opened a pull request:

    https://github.com/apache/carbondata/pull/1433

    [CARBONDATA-1517]- Pre Aggregate Create Table Support

     Support CTAS in carbon and support creating aggregation tables using CTAS and update aggregation table information to main table schema.

You can merge this pull request into a Git repository by running:

    $ git pull https://github.com/kumarvishal09/incubator-carbondata pre-aggregate_Latest

Alternatively you can review and apply these changes as the patch at:

    https://github.com/apache/carbondata/pull/1433.patch

To close this pull request, make a commit to your master/trunk branch
with (at least) the following in the commit message:

    This closes #1433
   
----
commit 2b1ac0bdefa1da6b35727c887bca75be404f26ac
Author: kumarvishal <[hidden email]>
Date:   2017-10-15T12:35:55Z

    aggsupport

----


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    SDV Build Fail , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/1303/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/666/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r146761132
 
    --- Diff: integration/spark2/src/main/scala/org/apache/spark/sql/execution/command/preaaggregate/PreAggregateUtil.scala ---
    @@ -0,0 +1,435 @@
    +/*
    + * 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.
    + */
    +package org.apache.spark.sql.execution.command.preaaggregate
    +
    +import scala.collection.mutable.ListBuffer
    +
    +import org.apache.spark.SparkConf
    +import org.apache.spark.sql.{CarbonDatasourceHadoopRelation, CarbonEnv, SparkSession}
    +import org.apache.spark.sql.catalyst.TableIdentifier
    +import org.apache.spark.sql.catalyst.expressions.{Alias, AttributeReference, Cast}
    +import org.apache.spark.sql.catalyst.expressions.aggregate._
    +import org.apache.spark.sql.catalyst.plans.logical._
    +import org.apache.spark.sql.execution.command.{ColumnTableRelation, Field}
    +import org.apache.spark.sql.execution.datasources.LogicalRelation
    +import org.apache.spark.sql.hive.{CarbonRelation, CarbonSessionState}
    +import org.apache.spark.sql.hive.HiveExternalCatalog.{DATASOURCE_SCHEMA_NUMPARTS, DATASOURCE_SCHEMA_PART_PREFIX}
    +import org.apache.spark.sql.types.DataType
    +
    +import org.apache.carbondata.common.logging.{LogService, LogServiceFactory}
    +import org.apache.carbondata.core.constants.CarbonCommonConstants
    +import org.apache.carbondata.core.locks.{CarbonLockUtil, ICarbonLock, LockUsage}
    +import org.apache.carbondata.core.metadata.converter.ThriftWrapperSchemaConverterImpl
    +import org.apache.carbondata.core.metadata.schema.table.{CarbonTable, DataMapSchema}
    +import org.apache.carbondata.core.util.path.CarbonStorePath
    +import org.apache.carbondata.format.TableInfo
    +import org.apache.carbondata.spark.exception.MalformedCarbonCommandException
    +import org.apache.carbondata.spark.util.CommonUtil
    +
    +/**
    + * Utility class for keeping all the utility method for pre-aggregate
    + */
    +object PreAggregateUtil {
    +
    +  private val LOGGER = LogServiceFactory.getLogService(this.getClass.getCanonicalName)
    +
    +  def getParentCarbonTable(plan: LogicalPlan): CarbonTable = {
    +    plan match {
    +      case Aggregate(_, aExp, SubqueryAlias(_, l: LogicalRelation, _))
    +        if l.relation.isInstanceOf[CarbonDatasourceHadoopRelation] =>
    +        l.relation.asInstanceOf[CarbonDatasourceHadoopRelation].carbonRelation.metaData.carbonTable
    +      case _ => throw new MalformedCarbonCommandException("table does not exist")
    +    }
    +  }
    +
    +  /**
    +   * Below method will be used to validate the select plan
    +   * and get the required fields from select plan
    +   * Currently only aggregate query is support any other type of query will
    +   * fail
    +   * @param plan
    +   * @param selectStmt
    +   * @return list of fields
    +   */
    +  def validateActualSelectPlanAndGetAttrubites(plan: LogicalPlan,
    +      selectStmt: String): Seq[Field] = {
    +    val list = scala.collection.mutable.LinkedHashSet.empty[Field]
    +    plan match {
    +      case Aggregate(_, aExp, SubqueryAlias(_, l: LogicalRelation, _))
    +        if l.relation.isInstanceOf[CarbonDatasourceHadoopRelation] =>
    +        val carbonTable = l.relation.asInstanceOf[CarbonDatasourceHadoopRelation].carbonRelation
    +          .metaData.carbonTable
    +        val parentTableName = carbonTable.getAbsoluteTableIdentifier.getCarbonTableIdentifier
    +          .getTableName
    +        val parentDatabaseName = carbonTable.getAbsoluteTableIdentifier.getCarbonTableIdentifier
    +          .getDatabaseName
    +        val parentTableId = carbonTable.getAbsoluteTableIdentifier.getCarbonTableIdentifier
    +          .getTableId
    +        if (!carbonTable.getTableInfo.getParentRelationIdentifiers.isEmpty) {
    +          throw new MalformedCarbonCommandException(
    +            "Pre Aggregation is not supported on Pre-Aggregated Table")
    +        }
    +        aExp.map {
    +          case Alias(attr: AggregateExpression, _) =>
    +            if (attr.isDistinct) {
    +              throw new MalformedCarbonCommandException(
    +                "Distinct is not supported On Pre Aggregation")
    +            }
    +            list ++= validateAggregateFunctionAndGetFields(carbonTable,
    +              attr.aggregateFunction,
    +              parentTableName,
    +              parentDatabaseName,
    +              parentTableId)
    +          case attr: AttributeReference =>
    +            list += getField(attr.name,
    +              attr.dataType,
    +              parentColumnId = carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +              parentTableName = parentTableName,
    +              parentDatabaseName = parentDatabaseName, parentTableId = parentTableId)
    +          case Alias(attr: AttributeReference, _) =>
    +            list += getField(attr.name,
    +              attr.dataType,
    +              parentColumnId = carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +              parentTableName = parentTableName,
    +              parentDatabaseName = parentDatabaseName, parentTableId = parentTableId)
    +          case _ =>
    +            throw new MalformedCarbonCommandException(s"Unsupported Select Statement:${
    +              selectStmt } ")
    +        }
    +        Some(carbonTable)
    +      case _ =>
    +        throw new MalformedCarbonCommandException(s"Unsupported Select Statement:${ selectStmt } ")
    +    }
    +    list.toSeq
    +  }
    +
    +  /**
    +   * Below method will be used to validate about the aggregate function
    +   * which is applied on select query.
    +   * Currently sum, max, min, count, avg is supported
    +   * in case of any other aggregate function it will throw error
    +   * In case of avg it will return two fields one for count
    +   * and other of sum of that column to support rollup
    +   * @param carbonTable
    +   * @param aggFunctions
    +   * @param parentTableName
    +   * @param parentDatabaseName
    +   * @param parentTableId
    +   * @return list of fields
    +   */
    +  def validateAggregateFunctionAndGetFields(carbonTable: CarbonTable,
    +      aggFunctions: AggregateFunction,
    +      parentTableName: String,
    +      parentDatabaseName: String,
    +      parentTableId: String) : scala.collection.mutable.ListBuffer[Field] = {
    +    val list = scala.collection.mutable.ListBuffer.empty[Field]
    +    aggFunctions match {
    +      case sum@Sum(attr: AttributeReference) =>
    +        list += getField(attr.name,
    +          attr.dataType,
    +          sum.prettyName,
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case sum@Sum(Cast(attr: AttributeReference, changeDataType: DataType)) =>
    +        list += getField(attr.name,
    +          changeDataType,
    +          sum.prettyName,
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case count@Count(Seq(attr: AttributeReference)) =>
    +        list += getField(attr.name,
    +          attr.dataType,
    +          count.prettyName,
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case min@Min(attr: AttributeReference) =>
    +        list += getField(attr.name,
    +          attr.dataType,
    +          min.prettyName,
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case min@Min(Cast(attr: AttributeReference, changeDataType: DataType)) =>
    +        list += getField(attr.name,
    +          changeDataType,
    +          min.prettyName,
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case max@Max(attr: AttributeReference) =>
    +        list += getField(attr.name,
    +          attr.dataType,
    +          max.prettyName,
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case max@Max(Cast(attr: AttributeReference, changeDataType: DataType)) =>
    +        list += getField(attr.name,
    +          changeDataType,
    +          max.prettyName,
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case Average(attr: AttributeReference) =>
    +        list += getField(attr.name,
    +          attr.dataType,
    +          "sum",
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +        list += getField(attr.name,
    +          attr.dataType,
    +          "count",
    +          carbonTable.getColumnByName(parentTableName, attr.name).getColumnId,
    +          parentTableName,
    +          parentDatabaseName, parentTableId = parentTableId)
    +      case Average(Cast(attr: AttributeReference, changeDataType: DataType)) =>
    --- End diff --
   
    I think it would be issue if it is used the changedDataType. Even while querying also we should need to check the datatype. Better don't take this type of aggfunction  in first phase.


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r146761652
 
    --- Diff: integration/spark-common/src/main/scala/org/apache/carbondata/spark/util/CommonUtil.scala ---
    @@ -831,4 +832,12 @@ object CommonUtil {
             LOGGER.error(s)
         }
       }
    +
    +  def getScaleAndPrecision(dataType: String): (Int, Int) = {
    --- End diff --
   
    This method is duplicated. Please reuse it


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r146763017
 
    --- Diff: integration/spark-common/src/main/scala/org/apache/spark/sql/catalyst/CarbonDDLSqlParser.scala ---
    @@ -1023,31 +1023,39 @@ abstract class CarbonDDLSqlParser extends AbstractCarbonSparkSQLParser {
         dataType match {
           case "string" =>
             Field(field.column, Some("String"), field.name, Some(null), field.parent,
    -        field.storeType, field.schemaOrdinal, field.precision, field.scale, field.rawSchema
    +        field.storeType, field.schemaOrdinal, field.precision, field.scale, field.rawSchema,
    --- End diff --
   
    Instead of changing Field can you add another class for extra information and wrap the Field into it. Better try t avoid old classes. This Field already has lot of paramaters


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r146764092
 
    --- Diff: integration/spark2/src/main/scala/org/apache/spark/sql/hive/CarbonMetaStore.scala ---
    @@ -66,25 +66,42 @@ trait CarbonMetaStore {
        * @param carbonStorePath
        * @param sparkSession
        */
    -  def updateTableSchema(newTableIdentifier: CarbonTableIdentifier,
    +  def updateTableSchemaForAlter(newTableIdentifier: CarbonTableIdentifier,
           oldTableIdentifier: CarbonTableIdentifier,
           thriftTableInfo: org.apache.carbondata.format.TableInfo,
           schemaEvolutionEntry: SchemaEvolutionEntry,
           carbonStorePath: String)(sparkSession: SparkSession): String
     
       /**
    +   * This method will overwrite the existing schema and update it with the given details
    +   *
    +   * @param newTableIdentifier
    +   * @param thriftTableInfo
    +   * @param carbonStorePath
    +   * @param sparkSession
    +   */
    +  def updateTableSchemaForPreAgg(newTableIdentifier: CarbonTableIdentifier,
    --- End diff --
   
    Better name as updateTableSchemaForDataMap


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r146764194
 
    --- Diff: integration/spark2/src/main/scala/org/apache/spark/sql/hive/CarbonFileMetastore.scala ---
    @@ -110,6 +111,40 @@ class CarbonFileMetastore extends CarbonMetaStore {
         }
       }
     
    +  /**
    +   * This method will overwrite the existing schema and update it with the given details
    +   *
    +   * @param newTableIdentifier
    +   * @param thriftTableInfo
    +   * @param carbonStorePath
    +   * @param sparkSession
    +   */
    +  def updateTableSchemaForPreAgg(newTableIdentifier: CarbonTableIdentifier,
    +      oldTableIdentifier: CarbonTableIdentifier,
    +      thriftTableInfo: org.apache.carbondata.format.TableInfo,
    +      carbonStorePath: String)(sparkSession: SparkSession): String = {
    +    val absoluteTableIdentifier = AbsoluteTableIdentifier.fromTablePath(carbonStorePath)
    --- End diff --
   
    check  if you can reuse the code of `updateTableSchemaForAlter`


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user kumarvishal09 commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r147226705
 
    --- Diff: integration/spark2/src/main/scala/org/apache/spark/sql/hive/CarbonMetaStore.scala ---
    @@ -66,25 +66,42 @@ trait CarbonMetaStore {
        * @param carbonStorePath
        * @param sparkSession
        */
    -  def updateTableSchema(newTableIdentifier: CarbonTableIdentifier,
    +  def updateTableSchemaForAlter(newTableIdentifier: CarbonTableIdentifier,
           oldTableIdentifier: CarbonTableIdentifier,
           thriftTableInfo: org.apache.carbondata.format.TableInfo,
           schemaEvolutionEntry: SchemaEvolutionEntry,
           carbonStorePath: String)(sparkSession: SparkSession): String
     
       /**
    +   * This method will overwrite the existing schema and update it with the given details
    +   *
    +   * @param newTableIdentifier
    +   * @param thriftTableInfo
    +   * @param carbonStorePath
    +   * @param sparkSession
    +   */
    +  def updateTableSchemaForPreAgg(newTableIdentifier: CarbonTableIdentifier,
    --- End diff --
   
    ok


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user kumarvishal09 commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r147227377
 
    --- Diff: integration/spark2/src/main/scala/org/apache/spark/sql/hive/CarbonFileMetastore.scala ---
    @@ -110,6 +111,40 @@ class CarbonFileMetastore extends CarbonMetaStore {
         }
       }
     
    +  /**
    +   * This method will overwrite the existing schema and update it with the given details
    +   *
    +   * @param newTableIdentifier
    +   * @param thriftTableInfo
    +   * @param carbonStorePath
    +   * @param sparkSession
    +   */
    +  def updateTableSchemaForPreAgg(newTableIdentifier: CarbonTableIdentifier,
    +      oldTableIdentifier: CarbonTableIdentifier,
    +      thriftTableInfo: org.apache.carbondata.format.TableInfo,
    +      carbonStorePath: String)(sparkSession: SparkSession): String = {
    +    val absoluteTableIdentifier = AbsoluteTableIdentifier.fromTablePath(carbonStorePath)
    --- End diff --
   
    ok


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user kumarvishal09 commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r147227445
 
    --- Diff: integration/spark-common/src/main/scala/org/apache/carbondata/spark/util/CommonUtil.scala ---
    @@ -831,4 +832,12 @@ object CommonUtil {
             LOGGER.error(s)
         }
       }
    +
    +  def getScaleAndPrecision(dataType: String): (Int, Int) = {
    --- End diff --
   
    ok


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata pull request #1433: [CARBONDATA-1517]- Pre Aggregate Create Table...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user kumarvishal09 commented on a diff in the pull request:

    https://github.com/apache/carbondata/pull/1433#discussion_r147234581
 
    --- Diff: integration/spark-common/src/main/scala/org/apache/carbondata/spark/util/CommonUtil.scala ---
    @@ -831,4 +832,12 @@ object CommonUtil {
             LOGGER.error(s)
         }
       }
    +
    +  def getScaleAndPrecision(dataType: String): (Int, Int) = {
    --- End diff --
   
    Moved this method to commonutils and updated all the callers


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/688/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    Build Failed  with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/692/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/1326/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/1327/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/697/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    SDV Build Success , Please check CI http://144.76.159.231:8080/job/ApacheSDVTests/1332/



---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user ravipesala commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    LGTM


---
Reply | Threaded
Open this post in threaded view
|

[GitHub] carbondata issue #1433: [CARBONDATA-1517]- Pre Aggregate Create Table Suppor...

qiuchenjian-2
In reply to this post by qiuchenjian-2
Github user CarbonDataQA commented on the issue:

    https://github.com/apache/carbondata/pull/1433
 
    Build Success with Spark 2.1.0, Please check CI http://136.243.101.176:8080/job/ApacheCarbonPRBuilder1/862/



---
12