Binary compatibility report for the hivemall-spark-0.0.2 library  between 1.4.0 and 1.0.0 versions   (relating to the portability of client application hivemall-spark-0.0.2.jar)

Test Info


Library Namehivemall-spark-0.0.2
Version #11.4.0
Version #21.0.0
Java Version1.7.0_75

Test Results


Total Java ARchives3
Total Methods / Classes353 / 1294
VerdictIncompatible
(88.4%)

Problem Summary


SeverityCount
Added Methods-34
Removed MethodsHigh298
Problems with
Data Types
High10
Medium0
Low1
Problems with
Methods
High0
Medium0
Low0

Added Methods (34)


spark-hive_2.10-1.0.0.jar, HiveContext.class
package org.apache.spark.sql.hive
HiveContext.createTable ( String tableName, boolean allowExisting, scala.reflect.api.TypeTags.TypeTag<A> p3 )  :  void
HiveContext.emptyResult ( )  :  org.apache.spark.rdd.RDD<org.apache.spark.sql.catalyst.expressions.Row>
HiveContext.hiveql ( String hqlQuery )  :  org.apache.spark.sql.SchemaRDD
HiveContext.hql ( String hqlQuery )  :  org.apache.spark.sql.SchemaRDD
HiveContext.outputBuffer ( )  :  java.io.OutputStream
HiveContext.runHive ( String cmd, int maxRows )  :  scala.collection.Seq<String>
HiveContext.sessionState ( )  :  org.apache.hadoop.hive.ql.session.SessionState

spark-sql_2.10-1.0.0.jar, SQLContext.class
package org.apache.spark.sql
SQLContext.binaryToLiteral ( byte[ ] a )  :  catalyst.expressions.Literal
SQLContext.booleanToLiteral ( boolean b )  :  catalyst.expressions.Literal
SQLContext.byteToLiteral ( byte b )  :  catalyst.expressions.Literal
SQLContext.createParquetFile ( String path, boolean allowExisting, org.apache.hadoop.conf.Configuration conf, scala.reflect.api.TypeTags.TypeTag<A> p4 )  :  SchemaRDD
SQLContext.createSchemaRDD ( org.apache.spark.rdd.RDD<A> rdd, scala.reflect.api.TypeTags.TypeTag<A> p2 )  :  SchemaRDD
SQLContext.decimalToLiteral ( scala.math.BigDecimal d )  :  catalyst.expressions.Literal
SQLContext.doubleToLiteral ( double d )  :  catalyst.expressions.Literal
SQLContext.DslAttribute ( catalyst.expressions.AttributeReference a )  :  catalyst.dsl.package.ExpressionConversions.DslAttribute
SQLContext.DslExpression ( catalyst.expressions.Expression e )  :  catalyst.dsl.package.ExpressionConversions.DslExpression
SQLContext.DslString ( String s )  :  catalyst.dsl.package.ExpressionConversions.DslString
SQLContext.DslSymbol ( scala.Symbol sym )  :  catalyst.dsl.package.ExpressionConversions.DslSymbol
SQLContext.floatToLiteral ( float f )  :  catalyst.expressions.Literal
SQLContext.inferSchema ( org.apache.spark.rdd.RDD<scala.collection.immutable.Map<String,Object>> rdd )  :  SchemaRDD
SQLContext.intToLiteral ( int i )  :  catalyst.expressions.Literal
SQLContext.logger ( )  :  com.typesafe.scalalogging.slf4j.Logger
SQLContext.logicalPlanToSparkQuery ( catalyst.plans.logical.LogicalPlan plan )  :  SchemaRDD
SQLContext.longToLiteral ( long l )  :  catalyst.expressions.Literal
SQLContext.optimizer ( )  :  catalyst.optimizer.Optimizer.
SQLContext.parquetFile ( String path )  :  SchemaRDD
SQLContext.parser ( )  :  catalyst.SqlParser
SQLContext.registerRDDAsTable ( SchemaRDD rdd, String tableName )  :  void
SQLContext.shortToLiteral ( short s )  :  catalyst.expressions.Literal
SQLContext.sql ( String sqlText )  :  SchemaRDD
SQLContext.stringToLiteral ( String s )  :  catalyst.expressions.Literal
SQLContext.symbolToUnresolvedAttribute ( scala.Symbol s )  :  catalyst.analysis.UnresolvedAttribute
SQLContext.table ( String tableName )  :  SchemaRDD
SQLContext.timestampToLiteral ( java.sql.Timestamp t )  :  catalyst.expressions.Literal

to the top

Removed Methods (298)


spark-hive_2.10-1.4.0.jar, HiveContext.class
package org.apache.spark.sql.hive
HiveContext.analyze ( String tableName )  :  void
HiveContext.configure ( )  :  scala.collection.immutable.Map<String,String>
HiveContext.convertCTAS ( )  :  boolean
HiveContext.convertMetastoreParquet ( )  :  boolean
HiveContext.convertMetastoreParquetWithSchemaMerging ( )  :  boolean
HiveContext.createSession ( )  :  HiveContext.SQLSession
HiveContext.createSession ( )  :  org.apache.spark.sql.SQLContext.SQLSession
HiveContext.dialectClassName ( )  :  String
HiveContext.executionHive ( )  :  client.ClientWrapper
HiveContext.functionRegistry ( )  :  org.apache.spark.sql.catalyst.analysis.FunctionRegistry
HiveContext.functionRegistry ( )  :  HiveFunctionRegistry
HiveContext.HIVE_METASTORE_JARS ( ) [static]  :  String
HiveContext.HIVE_METASTORE_VERSION ( ) [static]  :  String
HiveContext.hiveExecutionVersion ( ) [static]  :  String
HiveContext.hiveMetastoreBarrierPrefixes ( )  :  scala.collection.Seq<String>
HiveContext.hiveMetastoreJars ( )  :  String
HiveContext.hiveMetastoreSharedPrefixes ( )  :  scala.collection.Seq<String>
HiveContext.hiveMetastoreVersion ( )  :  String
HiveContext.invalidateTable ( String tableName )  :  void
HiveContext.metadataHive ( )  :  client.ClientInterface
HiveContext.newTemporaryConfiguration ( ) [static]  :  scala.collection.immutable.Map<String,String>
HiveContext.refreshTable ( String tableName )  :  void
HiveContext.setConf ( String key, String value )  :  void
HiveContext.substitutor ( )  :  org.apache.hadoop.hive.ql.parse.VariableSubstitution
HiveContext.toHiveStructString ( scala.Tuple2<Object,org.apache.spark.sql.types.DataType> p1 ) [static]  :  String

spark-hive_2.10-1.4.0.jar, HiveFunctionWrapper.class
package org.apache.spark.sql.hive
HiveFunctionWrapper.andThen ( scala.Function1<HiveFunctionWrapper,A> p1 ) [static]  :  scala.Function1<String,A>
HiveFunctionWrapper.canEqual ( Object p1 )  :  boolean
HiveFunctionWrapper.compose ( scala.Function1<A,String> p1 ) [static]  :  scala.Function1<A,HiveFunctionWrapper>
HiveFunctionWrapper.copy ( String functionClassName )  :  HiveFunctionWrapper
HiveFunctionWrapper.createFunction ( )  :  UDFType
HiveFunctionWrapper.deserializeObjectByKryo ( com.esotericsoftware.kryo.Kryo kryo, java.io.InputStream in, Class<?> clazz, scala.reflect.ClassTag<T> p4 )  :  T
HiveFunctionWrapper.deserializePlan ( java.io.InputStream is, Class<?> clazz )  :  UDFType
HiveFunctionWrapper.equals ( Object p1 )  :  boolean
HiveFunctionWrapper.functionClassName ( )  :  String
HiveFunctionWrapper.functionClassName_.eq ( String p1 )  :  void
HiveFunctionWrapper.hashCode ( )  :  int
HiveFunctionWrapper.HiveFunctionWrapper ( )
HiveFunctionWrapper.HiveFunctionWrapper ( String functionClassName )
HiveFunctionWrapper.productArity ( )  :  int
HiveFunctionWrapper.productElement ( int p1 )  :  Object
HiveFunctionWrapper.productIterator ( )  :  scala.collection.Iterator<Object>
HiveFunctionWrapper.productPrefix ( )  :  String
HiveFunctionWrapper.readExternal ( java.io.ObjectInput in )  :  void
HiveFunctionWrapper.serializeObjectByKryo ( com.esotericsoftware.kryo.Kryo kryo, Object plan, java.io.OutputStream out )  :  void
HiveFunctionWrapper.serializePlan ( Object function, java.io.OutputStream out )  :  void
HiveFunctionWrapper.toString ( )  :  String
HiveFunctionWrapper.writeExternal ( java.io.ObjectOutput out )  :  void

spark-hive_2.10-1.4.0.jar, HiveGenericUdf.class
package org.apache.spark.sql.hive
HiveGenericUdf.HiveGenericUdf ( HiveFunctionWrapper funcWrapper, scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> children )

spark-hive_2.10-1.4.0.jar, HiveGenericUdtf.class
package org.apache.spark.sql.hive
HiveGenericUdtf.HiveGenericUdtf ( HiveFunctionWrapper funcWrapper, scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> children )

spark-hive_2.10-1.4.0.jar, HiveSimpleUdf.class
package org.apache.spark.sql.hive
HiveSimpleUdf.HiveSimpleUdf ( HiveFunctionWrapper funcWrapper, scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> children )

spark-hive_2.10-1.4.0.jar, ShimFileSinkDesc.class
package org.apache.spark.sql.hive
ShimFileSinkDesc.compressCodec ( )  :  String
ShimFileSinkDesc.compressCodec_.eq ( String p1 )  :  void
ShimFileSinkDesc.compressed ( )  :  boolean
ShimFileSinkDesc.compressed_.eq ( boolean p1 )  :  void
ShimFileSinkDesc.compressType ( )  :  String
ShimFileSinkDesc.compressType_.eq ( String p1 )  :  void
ShimFileSinkDesc.destTableId ( )  :  int
ShimFileSinkDesc.destTableId_.eq ( int p1 )  :  void
ShimFileSinkDesc.dir ( )  :  String
ShimFileSinkDesc.dir_.eq ( String p1 )  :  void
ShimFileSinkDesc.getDirName ( )  :  String
ShimFileSinkDesc.isTraceEnabled ( )  :  boolean
ShimFileSinkDesc.log ( )  :  org.slf4j.Logger
ShimFileSinkDesc.logDebug ( scala.Function0<String> msg )  :  void
ShimFileSinkDesc.logDebug ( scala.Function0<String> msg, Throwable throwable )  :  void
ShimFileSinkDesc.logError ( scala.Function0<String> msg )  :  void
ShimFileSinkDesc.logError ( scala.Function0<String> msg, Throwable throwable )  :  void
ShimFileSinkDesc.logInfo ( scala.Function0<String> msg )  :  void
ShimFileSinkDesc.logInfo ( scala.Function0<String> msg, Throwable throwable )  :  void
ShimFileSinkDesc.logName ( )  :  String
ShimFileSinkDesc.logTrace ( scala.Function0<String> msg )  :  void
ShimFileSinkDesc.logTrace ( scala.Function0<String> msg, Throwable throwable )  :  void
ShimFileSinkDesc.logWarning ( scala.Function0<String> msg )  :  void
ShimFileSinkDesc.logWarning ( scala.Function0<String> msg, Throwable throwable )  :  void
ShimFileSinkDesc.org.apache.spark.Logging..log_ ( )  :  org.slf4j.Logger
ShimFileSinkDesc.org.apache.spark.Logging..log__.eq ( org.slf4j.Logger p1 )  :  void
ShimFileSinkDesc.setCompressCodec ( String intermediateCompressorCodec )  :  void
ShimFileSinkDesc.setCompressed ( boolean compressed )  :  void
ShimFileSinkDesc.setCompressType ( String intermediateCompressType )  :  void
ShimFileSinkDesc.setDestTableId ( int destTableId )  :  void
ShimFileSinkDesc.setTableInfo ( org.apache.hadoop.hive.ql.plan.TableDesc tableInfo )  :  void
ShimFileSinkDesc.ShimFileSinkDesc ( String dir, org.apache.hadoop.hive.ql.plan.TableDesc tableInfo, boolean compressed )
ShimFileSinkDesc.tableInfo ( )  :  org.apache.hadoop.hive.ql.plan.TableDesc
ShimFileSinkDesc.tableInfo_.eq ( org.apache.hadoop.hive.ql.plan.TableDesc p1 )  :  void

spark-sql_2.10-1.4.0.jar, Column.class
package org.apache.spark.sql
Column.as ( String alias )  :  Column

spark-sql_2.10-1.4.0.jar, DataFrame.class
package org.apache.spark.sql
DataFrame.agg ( java.util.Map<String,String> exprs )  :  DataFrame
DataFrame.agg ( Column expr, Column... exprs )  :  DataFrame
DataFrame.agg ( Column expr, scala.collection.Seq<Column> exprs )  :  DataFrame
DataFrame.agg ( scala.collection.immutable.Map<String,String> exprs )  :  DataFrame
DataFrame.agg ( scala.Tuple2<String,String> aggExpr, scala.collection.Seq<scala.Tuple2<String,String>> aggExprs )  :  DataFrame
DataFrame.apply ( String colName )  :  Column
DataFrame.as ( scala.Symbol alias )  :  DataFrame
DataFrame.as ( String alias )  :  DataFrame
DataFrame.cache ( )  :  DataFrame
DataFrame.cache ( )  :  RDDApi
DataFrame.coalesce ( int numPartitions )  :  DataFrame
DataFrame.col ( String colName )  :  Column
DataFrame.collect ( )  :  Object
DataFrame.collect ( )  :  Row[ ]
DataFrame.collectAsList ( )  :  java.util.List<Row>
DataFrame.columns ( )  :  String[ ]
DataFrame.count ( )  :  long
DataFrame.cube ( Column... cols )  :  GroupedData
DataFrame.cube ( scala.collection.Seq<Column> cols )  :  GroupedData
DataFrame.cube ( String col1, scala.collection.Seq<String> cols )  :  GroupedData
DataFrame.cube ( String col1, String... cols )  :  GroupedData
DataFrame.DataFrame ( SQLContext sqlContext, catalyst.plans.logical.LogicalPlan logicalPlan )
DataFrame.DataFrame ( SQLContext sqlContext, SQLContext.QueryExecution queryExecution )
DataFrame.describe ( scala.collection.Seq<String> cols )  :  DataFrame
DataFrame.describe ( String... cols )  :  DataFrame
DataFrame.distinct ( )  :  DataFrame
DataFrame.drop ( String colName )  :  DataFrame
DataFrame.dropDuplicates ( )  :  DataFrame
DataFrame.dropDuplicates ( scala.collection.Seq<String> colNames )  :  DataFrame
DataFrame.dropDuplicates ( String[ ] colNames )  :  DataFrame
DataFrame.dtypes ( )  :  scala.Tuple2<String,String>[ ]
DataFrame.except ( DataFrame other )  :  DataFrame
DataFrame.explain ( )  :  void
DataFrame.explain ( boolean extended )  :  void
DataFrame.explode ( scala.collection.Seq<Column> input, scala.Function1<Row,scala.collection.TraversableOnce<A>> f, scala.reflect.api.TypeTags.TypeTag<A> p3 )  :  DataFrame
DataFrame.explode ( String inputColumn, String outputColumn, scala.Function1<A,scala.collection.TraversableOnce<B>> f, scala.reflect.api.TypeTags.TypeTag<B> p4 )  :  DataFrame
DataFrame.filter ( Column condition )  :  DataFrame
DataFrame.filter ( String conditionExpr )  :  DataFrame
DataFrame.first ( )  :  Object
DataFrame.first ( )  :  Row
DataFrame.flatMap ( scala.Function1<Row,scala.collection.TraversableOnce<R>> f, scala.reflect.ClassTag<R> p2 )  :  org.apache.spark.rdd.RDD<R>
DataFrame.foreach ( scala.Function1<Row,scala.runtime.BoxedUnit> f )  :  void
DataFrame.foreachPartition ( scala.Function1<scala.collection.Iterator<Row>,scala.runtime.BoxedUnit> f )  :  void
DataFrame.groupBy ( Column... cols )  :  GroupedData
DataFrame.groupBy ( scala.collection.Seq<Column> cols )  :  GroupedData
DataFrame.groupBy ( String col1, scala.collection.Seq<String> cols )  :  GroupedData
DataFrame.groupBy ( String col1, String... cols )  :  GroupedData
DataFrame.head ( )  :  Row
DataFrame.head ( int n )  :  Row[ ]
DataFrame.intersect ( DataFrame other )  :  DataFrame
DataFrame.isLocal ( )  :  boolean
DataFrame.javaRDD ( )  :  org.apache.spark.api.java.JavaRDD<Row>
DataFrame.javaToPython ( )  :  org.apache.spark.api.java.JavaRDD<byte[ ]>
DataFrame.join ( DataFrame right )  :  DataFrame
DataFrame.join ( DataFrame right, Column joinExprs )  :  DataFrame
DataFrame.join ( DataFrame right, Column joinExprs, String joinType )  :  DataFrame
DataFrame.join ( DataFrame right, String usingColumn )  :  DataFrame
DataFrame.limit ( int n )  :  DataFrame
DataFrame.logicalPlan ( )  :  catalyst.plans.logical.LogicalPlan
DataFrame.map ( scala.Function1<Row,R> f, scala.reflect.ClassTag<R> p2 )  :  org.apache.spark.rdd.RDD<R>
DataFrame.mapPartitions ( scala.Function1<scala.collection.Iterator<Row>,scala.collection.Iterator<R>> f, scala.reflect.ClassTag<R> p2 )  :  org.apache.spark.rdd.RDD<R>
DataFrame.na ( )  :  DataFrameNaFunctions
DataFrame.numericColumns ( )  :  scala.collection.Seq<catalyst.expressions.Expression>
DataFrame.orderBy ( Column... sortExprs )  :  DataFrame
DataFrame.orderBy ( scala.collection.Seq<Column> sortExprs )  :  DataFrame
DataFrame.orderBy ( String sortCol, scala.collection.Seq<String> sortCols )  :  DataFrame
DataFrame.orderBy ( String sortCol, String... sortCols )  :  DataFrame
DataFrame.DataFrame..logicalPlanToDataFrame ( catalyst.plans.logical.LogicalPlan logicalPlan )  :  DataFrame
DataFrame.persist ( )  :  DataFrame
DataFrame.persist ( )  :  RDDApi
DataFrame.persist ( org.apache.spark.storage.StorageLevel newLevel )  :  DataFrame
DataFrame.persist ( org.apache.spark.storage.StorageLevel newLevel )  :  RDDApi
DataFrame.printSchema ( )  :  void
DataFrame.queryExecution ( )  :  SQLContext.QueryExecution
DataFrame.randomSplit ( double[ ] weights )  :  DataFrame[ ]
DataFrame.randomSplit ( double[ ] weights, long seed )  :  DataFrame[ ]
DataFrame.randomSplit ( scala.collection.immutable.List<Object> weights, long seed )  :  DataFrame[ ]
DataFrame.rdd ( )  :  org.apache.spark.rdd.RDD<Row>
DataFrame.registerTempTable ( String tableName )  :  void
DataFrame.repartition ( int numPartitions )  :  DataFrame
DataFrame.resolve ( String colName )  :  catalyst.expressions.NamedExpression
DataFrame.rollup ( Column... cols )  :  GroupedData
DataFrame.rollup ( scala.collection.Seq<Column> cols )  :  GroupedData
DataFrame.rollup ( String col1, scala.collection.Seq<String> cols )  :  GroupedData
DataFrame.rollup ( String col1, String... cols )  :  GroupedData
DataFrame.sample ( boolean withReplacement, double fraction )  :  DataFrame
DataFrame.sample ( boolean withReplacement, double fraction, long seed )  :  DataFrame
DataFrame.schema ( )  :  types.StructType
DataFrame.select ( Column... cols )  :  DataFrame
DataFrame.select ( scala.collection.Seq<Column> cols )  :  DataFrame
DataFrame.select ( String col, scala.collection.Seq<String> cols )  :  DataFrame
DataFrame.select ( String col, String... cols )  :  DataFrame
DataFrame.selectExpr ( scala.collection.Seq<String> exprs )  :  DataFrame
DataFrame.selectExpr ( String... exprs )  :  DataFrame
DataFrame.show ( )  :  void
DataFrame.show ( int numRows )  :  void
DataFrame.showString ( int numRows )  :  String
DataFrame.sort ( Column... sortExprs )  :  DataFrame
DataFrame.sort ( scala.collection.Seq<Column> sortExprs )  :  DataFrame
DataFrame.sort ( String sortCol, scala.collection.Seq<String> sortCols )  :  DataFrame
DataFrame.sort ( String sortCol, String... sortCols )  :  DataFrame
DataFrame.sqlContext ( )  :  SQLContext
DataFrame.stat ( )  :  DataFrameStatFunctions
DataFrame.take ( int n )  :  Object
DataFrame.take ( int n )  :  Row[ ]
DataFrame.toDF ( )  :  DataFrame
DataFrame.toDF ( scala.collection.Seq<String> colNames )  :  DataFrame
DataFrame.toDF ( String... colNames )  :  DataFrame
DataFrame.toJavaRDD ( )  :  org.apache.spark.api.java.JavaRDD<Row>
DataFrame.toJSON ( )  :  org.apache.spark.rdd.RDD<String>
DataFrame.toString ( )  :  String
DataFrame.unionAll ( DataFrame other )  :  DataFrame
DataFrame.unpersist ( )  :  DataFrame
DataFrame.unpersist ( )  :  RDDApi
DataFrame.unpersist ( boolean blocking )  :  DataFrame
DataFrame.unpersist ( boolean blocking )  :  RDDApi
DataFrame.where ( Column condition )  :  DataFrame
DataFrame.withColumn ( String colName, Column col )  :  DataFrame
DataFrame.withColumnRenamed ( String existingName, String newName )  :  DataFrame
DataFrame.write ( )  :  DataFrameWriter

spark-sql_2.10-1.4.0.jar, GroupedData.class
package org.apache.spark.sql
GroupedData.agg ( java.util.Map<String,String> exprs )  :  DataFrame
GroupedData.agg ( Column expr, Column... exprs )  :  DataFrame
GroupedData.agg ( Column expr, scala.collection.Seq<Column> exprs )  :  DataFrame
GroupedData.agg ( scala.collection.immutable.Map<String,String> exprs )  :  DataFrame
GroupedData.agg ( scala.Tuple2<String,String> aggExpr, scala.collection.Seq<scala.Tuple2<String,String>> aggExprs )  :  DataFrame
GroupedData.apply ( DataFrame p1, scala.collection.Seq<catalyst.expressions.Expression> p2, GroupedData.GroupType p3 ) [static]  :  GroupedData
GroupedData.avg ( scala.collection.Seq<String> colNames )  :  DataFrame
GroupedData.avg ( String... colNames )  :  DataFrame
GroupedData.count ( )  :  DataFrame
GroupedData.GroupedData ( DataFrame df, scala.collection.Seq<catalyst.expressions.Expression> groupingExprs, GroupedData.GroupType groupType )
GroupedData.max ( scala.collection.Seq<String> colNames )  :  DataFrame
GroupedData.max ( String... colNames )  :  DataFrame
GroupedData.mean ( scala.collection.Seq<String> colNames )  :  DataFrame
GroupedData.mean ( String... colNames )  :  DataFrame
GroupedData.min ( scala.collection.Seq<String> colNames )  :  DataFrame
GroupedData.min ( String... colNames )  :  DataFrame
GroupedData.GroupedData..strToExpr ( String expr )  :  scala.Function1<catalyst.expressions.Expression,catalyst.expressions.Expression>
GroupedData.sum ( scala.collection.Seq<String> colNames )  :  DataFrame
GroupedData.sum ( String... colNames )  :  DataFrame

spark-sql_2.10-1.4.0.jar, SQLConf.class
package org.apache.spark.sql
SQLConf.dataFrameRetainGroupColumns ( )  :  boolean

spark-sql_2.10-1.4.0.jar, SQLContext.class
package org.apache.spark.sql
SQLContext.applySchemaToPythonRDD ( org.apache.spark.rdd.RDD<Object[ ]> rdd, types.StructType schema )  :  DataFrame
SQLContext.applySchemaToPythonRDD ( org.apache.spark.rdd.RDD<Object[ ]> rdd, String schemaString )  :  DataFrame
SQLContext.baseRelationToDataFrame ( sources.BaseRelation baseRelation )  :  DataFrame
SQLContext.cacheManager ( )  :  execution.CacheManager
SQLContext.clearCache ( )  :  void
SQLContext.conf ( )  :  SQLConf
SQLContext.createDataFrame ( org.apache.spark.api.java.JavaRDD<?> rdd, Class<?> beanClass )  :  DataFrame
SQLContext.createDataFrame ( org.apache.spark.api.java.JavaRDD<Row> rowRDD, types.StructType schema )  :  DataFrame
SQLContext.createDataFrame ( org.apache.spark.rdd.RDD<?> rdd, Class<?> beanClass )  :  DataFrame
SQLContext.createDataFrame ( org.apache.spark.rdd.RDD<A> rdd, scala.reflect.api.TypeTags.TypeTag<A> p2 )  :  DataFrame
SQLContext.createDataFrame ( org.apache.spark.rdd.RDD<Row> rowRDD, types.StructType schema )  :  DataFrame
SQLContext.createDataFrame ( org.apache.spark.rdd.RDD<Row> rowRDD, types.StructType schema, boolean needsConversion )  :  DataFrame
SQLContext.createDataFrame ( scala.collection.Seq<A> data, scala.reflect.api.TypeTags.TypeTag<A> p2 )  :  DataFrame
SQLContext.createExternalTable ( String tableName, String path )  :  DataFrame
SQLContext.createExternalTable ( String tableName, String path, String source )  :  DataFrame
SQLContext.createExternalTable ( String tableName, String source, java.util.Map<String,String> options )  :  DataFrame
SQLContext.createExternalTable ( String tableName, String source, types.StructType schema, java.util.Map<String,String> options )  :  DataFrame
SQLContext.createExternalTable ( String tableName, String source, types.StructType schema, scala.collection.immutable.Map<String,String> options )  :  DataFrame
SQLContext.createExternalTable ( String tableName, String source, scala.collection.immutable.Map<String,String> options )  :  DataFrame
SQLContext.createSession ( )  :  SQLContext.SQLSession
SQLContext.currentSession ( )  :  SQLContext.SQLSession
SQLContext.ddlParser ( )  :  sources.DDLParser
SQLContext.defaultSession ( )  :  SQLContext.SQLSession
SQLContext.detachSession ( )  :  void
SQLContext.dialectClassName ( )  :  String
SQLContext.dropTempTable ( String tableName )  :  void
SQLContext.emptyDataFrame ( )  :  DataFrame
SQLContext.emptyResult ( )  :  org.apache.spark.rdd.RDD<Row>
SQLContext.experimental ( )  :  ExperimentalMethods
SQLContext.functionRegistry ( )  :  catalyst.analysis.FunctionRegistry
SQLContext.getAllConfs ( )  :  scala.collection.immutable.Map<String,String>
SQLContext.getConf ( String key )  :  String
SQLContext.getConf ( String key, String defaultValue )  :  String
SQLContext.getOrCreate ( org.apache.spark.SparkContext p1 ) [static]  :  SQLContext
SQLContext.getSchema ( Class<?> beanClass )  :  scala.collection.Seq<catalyst.expressions.AttributeReference>
SQLContext.getSQLDialect ( )  :  catalyst.ParserDialect
SQLContext.implicits ( )  :  SQLContext.implicits.
SQLContext.isCached ( String tableName )  :  boolean
SQLContext.isTraceEnabled ( )  :  boolean
SQLContext.log ( )  :  org.slf4j.Logger
SQLContext.logDebug ( scala.Function0<String> msg )  :  void
SQLContext.logDebug ( scala.Function0<String> msg, Throwable throwable )  :  void
SQLContext.logError ( scala.Function0<String> msg )  :  void
SQLContext.logError ( scala.Function0<String> msg, Throwable throwable )  :  void
SQLContext.logInfo ( scala.Function0<String> msg )  :  void
SQLContext.logInfo ( scala.Function0<String> msg, Throwable throwable )  :  void
SQLContext.logName ( )  :  String
SQLContext.logTrace ( scala.Function0<String> msg )  :  void
SQLContext.logTrace ( scala.Function0<String> msg, Throwable throwable )  :  void
SQLContext.logWarning ( scala.Function0<String> msg )  :  void
SQLContext.logWarning ( scala.Function0<String> msg, Throwable throwable )  :  void
SQLContext.openSession ( )  :  SQLContext.SQLSession
SQLContext.optimizer ( )  :  catalyst.optimizer.Optimizer
SQLContext.org.apache.spark.Logging..log_ ( )  :  org.slf4j.Logger
SQLContext.org.apache.spark.Logging..log__.eq ( org.slf4j.Logger p1 )  :  void
SQLContext.parquetFile ( String... paths )  :  DataFrame
SQLContext.parseDataType ( String dataTypeString )  :  types.DataType
SQLContext.range ( long start, long end )  :  DataFrame
SQLContext.range ( long start, long end, long step, int numPartitions )  :  DataFrame
SQLContext.read ( )  :  DataFrameReader
SQLContext.registerDataFrameAsTable ( DataFrame df, String tableName )  :  void
SQLContext.setConf ( java.util.Properties props )  :  void
SQLContext.setConf ( String key, String value )  :  void
SQLContext.sql ( String sqlText )  :  DataFrame
SQLContext.SQLContext ( org.apache.spark.api.java.JavaSparkContext sparkContext )
SQLContext.sqlParser ( )  :  SparkSQLParser
SQLContext.table ( String tableName )  :  DataFrame
SQLContext.tableNames ( )  :  String[ ]
SQLContext.tableNames ( String databaseName )  :  String[ ]
SQLContext.tables ( )  :  DataFrame
SQLContext.tables ( String databaseName )  :  DataFrame
SQLContext.tlSession ( )  :  ThreadLocal<SQLContext.SQLSession>
SQLContext.udf ( )  :  UDFRegistration

to the top

Problems with Data Types, High Severity (10)


spark-hive_2.10-1.4.0.jar
package org.apache.spark.sql.hive
[+] HiveContext.QueryExecution (1)
[+] HiveFunctionWrapper (1)
[+] HiveMetastoreCatalog (1)
[+] ShimFileSinkDesc (1)

spark-sql_2.10-1.4.0.jar
package org.apache.spark.sql
[+] Column (1)
[+] DataFrame (1)
[+] GroupedData (1)
[+] SQLConf (1)
[+] SQLContext (1)
[+] SQLContext.QueryExecution (1)

to the top

Problems with Data Types, Low Severity (1)


spark-hive_2.10-1.4.0.jar
package org.apache.spark.sql.hive
[+] HiveContext (1)

to the top

Java ARchives (3)


spark-hive_2.10-1.4.0.jar
spark-mllib_2.10-1.4.0.jar
spark-sql_2.10-1.4.0.jar

to the top




Generated on Mon Jun 29 23:30:58 2015 for hivemall-spark-0.0.2 by Java API Compliance Checker 1.4.1  
A tool for checking backward compatibility of a Java library API