Binary compatibility report for the spark-es_2.10-1.0.7 library  between 1.6.0 and 1.4.0 versions   (relating to the portability of client application spark-es_2.10-1.0.7.jar)
Test Info
| Library Name | spark-es_2.10-1.0.7 | 
|---|
| Version #1 | 1.6.0 | 
|---|
| Version #2 | 1.4.0 | 
|---|
| Java Version | 1.7.0_85 | 
|---|
Test Results
| Total Java ARchives | 1 | 
|---|
| Total Methods / Classes | 364 / 2086 | 
|---|
| Verdict | Incompatible (13.2%)
 | 
|---|
Problem Summary
|  | Severity | Count | 
|---|
| Added Methods | - | 6 | 
|---|
| Removed Methods | High | 31 | 
|---|
| Problems with Data Types
 | High | 6 | 
|---|
| Medium | 0 | 
| Low | 0 | 
| Problems with Methods
 | High | 2 | 
|---|
| Medium | 0 | 
| Low | 0 | 
| Other Changes in Data Types
 | - | 1 | 
|---|
Added Methods (6)
spark-core_2.10-1.4.0.jar, RDD<T>.class
package org.apache.spark.rdd
RDD<T>.markCheckpointed ( RDD<?> checkpointRDD )  :  void
[mangled: org/apache/spark/rdd/RDD<T>.markCheckpointed:(Lorg/apache/spark/rdd/RDD;)V]
spark-core_2.10-1.4.0.jar, SparkContext.class
package org.apache.spark
SparkContext.preferredNodeLocationData ( )  :  scala.collection.Map<String,scala.collection.Set<scheduler.SplitInfo>>
[mangled: org/apache/spark/SparkContext.preferredNodeLocationData:()Lscala/collection/Map;]
SparkContext.preferredNodeLocationData_.eq ( scala.collection.Map<String,scala.collection.Set<scheduler.SplitInfo>> p1 )  :  void
[mangled: org/apache/spark/SparkContext.preferredNodeLocationData_.eq:(Lscala/collection/Map;)V]
SparkContext.requestTotalExecutors ( int numExecutors )  :  boolean
[mangled: org/apache/spark/SparkContext.requestTotalExecutors:(I)Z]
SparkContext.supportDynamicAllocation ( )  :  boolean
[mangled: org/apache/spark/SparkContext.supportDynamicAllocation:()Z]
spark-core_2.10-1.4.0.jar, TaskContext.class
package org.apache.spark
TaskContext.taskMemoryManager ( ) [abstract]  :  unsafe.memory.TaskMemoryManager
[mangled: org/apache/spark/TaskContext.taskMemoryManager:()Lorg/apache/spark/unsafe/memory/TaskMemoryManager;]
to the top
Removed Methods (31)
spark-core_2.10-1.6.0.jar, RDD<T>.class
package org.apache.spark.rdd
RDD<T>.getNumPartitions ( )  :  int
[mangled: org/apache/spark/rdd/RDD<T>.getNumPartitions:()I]
RDD<T>.isCheckpointedAndMaterialized ( )  :  boolean
[mangled: org/apache/spark/rdd/RDD<T>.isCheckpointedAndMaterialized:()Z]
RDD<T>.isLocallyCheckpointed ( )  :  boolean
[mangled: org/apache/spark/rdd/RDD<T>.isLocallyCheckpointed:()Z]
RDD<T>.localCheckpoint ( )  :  RDD<T>
[mangled: org/apache/spark/rdd/RDD<T>.localCheckpoint:()Lorg/apache/spark/rdd/RDD;]
RDD<T>.mapPartitionsInternal ( scala.Function1<scala.collection.Iterator<T>,scala.collection.Iterator<U>> f, boolean preservesPartitioning, scala.reflect.ClassTag<U> p3 )  :  RDD<U>
[mangled: org/apache/spark/rdd/RDD<T>.mapPartitionsInternal:(Lscala/Function1;ZLscala/reflect/ClassTag;)Lorg/apache/spark/rdd/RDD;]
RDD<T>.markCheckpointed ( )  :  void
[mangled: org/apache/spark/rdd/RDD<T>.markCheckpointed:()V]
spark-core_2.10-1.6.0.jar, SparkContext.class
package org.apache.spark
SparkContext.getRDDStorageInfo ( scala.Function1<rdd.RDD<?>,Object> filter )  :  storage.RDDInfo[ ]
[mangled: org/apache/spark/SparkContext.getRDDStorageInfo:(Lscala/Function1;)[Lorg/apache/spark/storage/RDDInfo;]
SparkContext.isStopped ( )  :  boolean
[mangled: org/apache/spark/SparkContext.isStopped:()Z]
SparkContext.killAndReplaceExecutor ( String executorId )  :  boolean
[mangled: org/apache/spark/SparkContext.killAndReplaceExecutor:(Ljava/lang/String;)Z]
SparkContext.SparkContext.._applicationId ( )  :  String
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._applicationId:()Ljava/lang/String;]
SparkContext.SparkContext.._cleaner ( )  :  scala.Option<ContextCleaner>
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._cleaner:()Lscala/Option;]
SparkContext.SparkContext.._dagScheduler ( )  :  scheduler.DAGScheduler
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._dagScheduler:()Lorg/apache/spark/scheduler/DAGScheduler;]
SparkContext.SparkContext.._eventLogger ( )  :  scala.Option<scheduler.EventLoggingListener>
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._eventLogger:()Lscala/Option;]
SparkContext.SparkContext.._executorAllocationManager ( )  :  scala.Option<ExecutorAllocationManager>
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._executorAllocationManager:()Lscala/Option;]
SparkContext.SparkContext.._heartbeatReceiver ( )  :  rpc.RpcEndpointRef
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._heartbeatReceiver:()Lorg/apache/spark/rpc/RpcEndpointRef;]
SparkContext.SparkContext.._listenerBusStarted_.eq ( boolean p1 )  :  void
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._listenerBusStarted_.eq:(Z)V]
SparkContext.SparkContext.._progressBar ( )  :  scala.Option<ui.ConsoleProgressBar>
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._progressBar:()Lscala/Option;]
SparkContext.SparkContext.._ui ( )  :  scala.Option<ui.SparkUI>
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext.._ui:()Lscala/Option;]
SparkContext.SparkContext..postApplicationEnd ( )  :  void
[mangled: org/apache/spark/SparkContext.org.apache.spark.SparkContext..postApplicationEnd:()V]
SparkContext.requestTotalExecutors ( int numExecutors, int localityAwareTasks, scala.collection.immutable.Map<String,Object> hostToLocalTaskCount )  :  boolean
[mangled: org/apache/spark/SparkContext.requestTotalExecutors:(IILscala/collection/immutable/Map;)Z]
SparkContext.runJob ( rdd.RDD<T> rdd, scala.Function1<scala.collection.Iterator<T>,U> func, scala.collection.Seq<Object> partitions, scala.reflect.ClassTag<U> p4 )  :  Object
[mangled: org/apache/spark/SparkContext.runJob:(Lorg/apache/spark/rdd/RDD;Lscala/Function1;Lscala/collection/Seq;Lscala/reflect/ClassTag;)Ljava/lang/Object;]
SparkContext.runJob ( rdd.RDD<T> rdd, scala.Function2<TaskContext,scala.collection.Iterator<T>,U> func, scala.collection.Seq<Object> partitions, scala.Function2<Object,U,scala.runtime.BoxedUnit> resultHandler, scala.reflect.ClassTag<U> p5 )  :  void
[mangled: org/apache/spark/SparkContext.runJob:(Lorg/apache/spark/rdd/RDD;Lscala/Function2;Lscala/collection/Seq;Lscala/Function2;Lscala/reflect/ClassTag;)V]
SparkContext.runJob ( rdd.RDD<T> rdd, scala.Function2<TaskContext,scala.collection.Iterator<T>,U> func, scala.collection.Seq<Object> partitions, scala.reflect.ClassTag<U> p4 )  :  Object
[mangled: org/apache/spark/SparkContext.runJob:(Lorg/apache/spark/rdd/RDD;Lscala/Function2;Lscala/collection/Seq;Lscala/reflect/ClassTag;)Ljava/lang/Object;]
SparkContext.submitMapStage ( ShuffleDependency<K,V,C> dependency )  :  SimpleFutureAction<MapOutputStatistics>
[mangled: org/apache/spark/SparkContext.submitMapStage:(Lorg/apache/spark/ShuffleDependency;)Lorg/apache/spark/SimpleFutureAction;]
spark-core_2.10-1.6.0.jar, TaskContext.class
package org.apache.spark
TaskContext.collectAccumulators ( ) [abstract]  :  scala.collection.immutable.Map<Object,Object>
[mangled: org/apache/spark/TaskContext.collectAccumulators:()Lscala/collection/immutable/Map;]
TaskContext.collectInternalAccumulators ( ) [abstract]  :  scala.collection.immutable.Map<Object,Object>
[mangled: org/apache/spark/TaskContext.collectInternalAccumulators:()Lscala/collection/immutable/Map;]
TaskContext.getMetricsSources ( String p1 ) [abstract]  :  scala.collection.Seq<metrics.source.Source>
[mangled: org/apache/spark/TaskContext.getMetricsSources:(Ljava/lang/String;)Lscala/collection/Seq;]
TaskContext.getPartitionId ( ) [static]  :  int
[mangled: org/apache/spark/TaskContext.getPartitionId:()I]
TaskContext.internalMetricsToAccumulators ( ) [abstract]  :  scala.collection.immutable.Map<String,Accumulator<Object>>
[mangled: org/apache/spark/TaskContext.internalMetricsToAccumulators:()Lscala/collection/immutable/Map;]
TaskContext.registerAccumulator ( Accumulable<?,?> p1 ) [abstract]  :  void
[mangled: org/apache/spark/TaskContext.registerAccumulator:(Lorg/apache/spark/Accumulable;)V]
TaskContext.taskMemoryManager ( ) [abstract]  :  memory.TaskMemoryManager
[mangled: org/apache/spark/TaskContext.taskMemoryManager:()Lorg/apache/spark/memory/TaskMemoryManager;]
to the top
Problems with Data Types, High Severity (6)
spark-core_2.10-1.6.0.jar
package org.apache.spark
[+] TaskContext (6)
|  | Change | Effect | 
|---|
| 1 | Abstract method collectAccumulators ( ) has been removed from this class. | A client program may be interrupted by NoSuchMethodError exception. | 
|---|
| 2 | Abstract method collectInternalAccumulators ( ) has been removed from this class. | A client program may be interrupted by NoSuchMethodError exception. | 
|---|
| 3 | Abstract method getMetricsSources ( java.lang.String ) has been removed from this class. | A client program may be interrupted by NoSuchMethodError exception. | 
|---|
| 4 | Abstract method internalMetricsToAccumulators ( ) has been removed from this class. | A client program may be interrupted by NoSuchMethodError exception. | 
|---|
| 5 | Abstract method registerAccumulator ( Accumulable<?,?> ) has been removed from this class. | A client program may be interrupted by NoSuchMethodError exception. | 
|---|
| 6 | Abstract method taskMemoryManager ( ) has been removed from this class. | A client program may be interrupted by NoSuchMethodError exception. | 
|---|
[+] affected methods (15)
compute ( Partition, TaskContext )2nd parameter 'p2'  of this abstract method has type 'TaskContext'.
computeOrReadCheckpoint ( Partition, TaskContext )2nd parameter 'context'  of this method has type 'TaskContext'.
iterator ( Partition, TaskContext )2nd parameter 'context'  of this method has type 'TaskContext'.
addTaskCompletionListener ( util.TaskCompletionListener )This abstract method is from 'TaskContext' abstract class.
addTaskCompletionListener ( scala.Function1<TaskContext,scala.runtime.BoxedUnit> )This abstract method is from 'TaskContext' abstract class.
attemptNumber ( )This abstract method is from 'TaskContext' abstract class.
get ( )This method is from 'TaskContext' abstract class.
isCompleted ( )This abstract method is from 'TaskContext' abstract class.
isInterrupted ( )This abstract method is from 'TaskContext' abstract class.
isRunningLocally ( )This abstract method is from 'TaskContext' abstract class.
partitionId ( )This abstract method is from 'TaskContext' abstract class.
stageId ( )This abstract method is from 'TaskContext' abstract class.
taskAttemptId ( )This abstract method is from 'TaskContext' abstract class.
TaskContext ( )This constructor is from 'TaskContext' abstract class.
taskMetrics ( )This abstract method is from 'TaskContext' abstract class.
  
 
to the top
Problems with Methods, High Severity (2)
spark-core_2.10-1.6.0.jar, SparkContext
package org.apache.spark
[+] SparkContext.localProperties ( )  :  InheritableThreadLocal<java.util.Properties> (1)
   [mangled: org/apache/spark/SparkContext.localProperties:()Ljava/lang/InheritableThreadLocal;]
|  | Change | Effect | 
|---|
| 1 | Access level has been changed from public to private. | A client program may be interrupted by IllegalAccessError exception. | 
|---|
 
[+] SparkContext.stopped ( )  :  java.util.concurrent.atomic.AtomicBoolean (1)
   [mangled: org/apache/spark/SparkContext.stopped:()Ljava/util/concurrent/atomic/AtomicBoolean;]
|  | Change | Effect | 
|---|
| 1 | Access level has been changed from public to private. | A client program may be interrupted by IllegalAccessError exception. | 
|---|
 
to the top
Other Changes in Data Types (1)
spark-core_2.10-1.6.0.jar
package org.apache.spark
[+] TaskContext (1)
|  | Change | Effect | 
|---|
| 1 | Abstract method taskMemoryManager ( ) has been added to this class. | No effect. | 
|---|
[+] affected methods (15)
compute ( Partition, TaskContext )2nd parameter 'p2'  of this abstract method has type 'TaskContext'.
computeOrReadCheckpoint ( Partition, TaskContext )2nd parameter 'context'  of this method has type 'TaskContext'.
iterator ( Partition, TaskContext )2nd parameter 'context'  of this method has type 'TaskContext'.
addTaskCompletionListener ( util.TaskCompletionListener )This abstract method is from 'TaskContext' abstract class.
addTaskCompletionListener ( scala.Function1<TaskContext,scala.runtime.BoxedUnit> )This abstract method is from 'TaskContext' abstract class.
attemptNumber ( )This abstract method is from 'TaskContext' abstract class.
get ( )This method is from 'TaskContext' abstract class.
isCompleted ( )This abstract method is from 'TaskContext' abstract class.
isInterrupted ( )This abstract method is from 'TaskContext' abstract class.
isRunningLocally ( )This abstract method is from 'TaskContext' abstract class.
partitionId ( )This abstract method is from 'TaskContext' abstract class.
stageId ( )This abstract method is from 'TaskContext' abstract class.
taskAttemptId ( )This abstract method is from 'TaskContext' abstract class.
TaskContext ( )This constructor is from 'TaskContext' abstract class.
taskMetrics ( )This abstract method is from 'TaskContext' abstract class.
  
 
to the top
Java ARchives (1)
spark-core_2.10-1.6.0.jar
to the top
Generated on Thu Feb  4 20:43:36 2016 for spark-es_2.10-1.0.7 by Java API Compliance Checker 1.4.1  
A tool for checking backward compatibility of a Java library API