You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@spark.apache.org by ya...@apache.org on 2023/06/15 16:49:28 UTC

[spark] branch master updated: [SPARK-44055][CORE] Remove redundant `override` functions from `CheckpointRDD`

This is an automated email from the ASF dual-hosted git repository.

yangjie01 pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/spark.git


The following commit(s) were added to refs/heads/master by this push:
     new fe4417c082d [SPARK-44055][CORE] Remove redundant `override` functions from `CheckpointRDD`
fe4417c082d is described below

commit fe4417c082d2a384bffe1337f7f1b77cef406b9d
Author: yangjie01 <ya...@baidu.com>
AuthorDate: Fri Jun 16 00:49:09 2023 +0800

    [SPARK-44055][CORE] Remove redundant `override` functions from `CheckpointRDD`
    
    ### What changes were proposed in this pull request?
    This pr aims to remove redundant `override` functions (`getPartitions` and `compute`) from `CheckpointRDD` due to the bug mentioned in the comment for mima check no longer exists.
    
    ### Why are the changes needed?
    Code Cleanup.
    
    ### Does this PR introduce _any_ user-facing change?
    No
    
    ### How was this patch tested?
    - Pass GitHub Actions
    - Manual checked:
    
    ```
    dev/mima
    ```
    
    and
    
    ```
    dev/change-scala-version.sh 2.13
    dev/mima -Pscala-2.13
    ```
    
    All passed.
    
    Closes #41597 from LuciferYang/SPARK-44055.
    
    Authored-by: yangjie01 <ya...@baidu.com>
    Signed-off-by: yangjie01 <ya...@baidu.com>
---
 core/src/main/scala/org/apache/spark/rdd/CheckpointRDD.scala | 10 +---------
 1 file changed, 1 insertion(+), 9 deletions(-)

diff --git a/core/src/main/scala/org/apache/spark/rdd/CheckpointRDD.scala b/core/src/main/scala/org/apache/spark/rdd/CheckpointRDD.scala
index b0364623af4..67a88a17b45 100644
--- a/core/src/main/scala/org/apache/spark/rdd/CheckpointRDD.scala
+++ b/core/src/main/scala/org/apache/spark/rdd/CheckpointRDD.scala
@@ -19,7 +19,7 @@ package org.apache.spark.rdd
 
 import scala.reflect.ClassTag
 
-import org.apache.spark.{Partition, SparkContext, TaskContext}
+import org.apache.spark.{Partition, SparkContext}
 
 /**
  * An RDD partition used to recover checkpointed data.
@@ -36,12 +36,4 @@ private[spark] abstract class CheckpointRDD[T: ClassTag](sc: SparkContext)
   override def doCheckpoint(): Unit = { }
   override def checkpoint(): Unit = { }
   override def localCheckpoint(): this.type = this
-
-  // Note: There is a bug in MiMa that complains about `AbstractMethodProblem`s in the
-  // base [[org.apache.spark.rdd.RDD]] class if we do not override the following methods.
-  // scalastyle:off
-  protected override def getPartitions: Array[Partition] = ???
-  override def compute(p: Partition, tc: TaskContext): Iterator[T] = ???
-  // scalastyle:on
-
 }


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@spark.apache.org
For additional commands, e-mail: commits-help@spark.apache.org