Skip to content

Commit f9fa03a

Browse files
committed
Fix scala checkstyle
1 parent 8e1dd8c commit f9fa03a

File tree

7 files changed

+8
-17
lines changed

7 files changed

+8
-17
lines changed

sql/core/src/main/scala/org/apache/spark/sql/execution/aggregate/MergingSessionsExec.scala

Lines changed: 0 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -17,8 +17,6 @@
1717

1818
package org.apache.spark.sql.execution.aggregate
1919

20-
import org.apache.spark.TaskContext
21-
2220
import org.apache.spark.rdd.RDD
2321
import org.apache.spark.sql.catalyst.InternalRow
2422
import org.apache.spark.sql.catalyst.expressions.{Ascending, Attribute, AttributeSet, Expression, NamedExpression, SortOrder, UnsafeRow}

sql/core/src/main/scala/org/apache/spark/sql/execution/aggregate/MergingSessionsIterator.scala

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -54,9 +54,9 @@ class MergingSessionsIterator(
5454

5555

5656
/**
57-
* Creates a new aggregation buffer and initializes buffer values
58-
* for all aggregate functions.
59-
*/
57+
* Creates a new aggregation buffer and initializes buffer values
58+
* for all aggregate functions.
59+
*/
6060
private def newBuffer: InternalRow = {
6161
val bufferSchema = aggregateFunctions.flatMap(_.aggBufferAttributes)
6262
val bufferRowSize: Int = bufferSchema.length

sql/core/src/main/scala/org/apache/spark/sql/execution/aggregate/UpdatingSessionExec.scala

Lines changed: 1 addition & 4 deletions
Original file line numberDiff line numberDiff line change
@@ -17,12 +17,9 @@
1717

1818
package org.apache.spark.sql.execution.aggregate
1919

20-
import org.apache.spark.TaskContext
21-
2220
import org.apache.spark.rdd.RDD
2321
import org.apache.spark.sql.catalyst.InternalRow
2422
import org.apache.spark.sql.catalyst.expressions.{Attribute, SortOrder}
25-
import org.apache.spark.sql.catalyst.expressions.codegen.GenerateUnsafeProjection
2623
import org.apache.spark.sql.catalyst.plans.physical.{Distribution, Partitioning}
2724
import org.apache.spark.sql.execution.{SparkPlan, UnaryExecNode}
2825

@@ -56,4 +53,4 @@ case class UpdatingSessionExec(
5653
case Some(ordering) => ordering
5754
case None => super.requiredChildOrdering
5855
}
59-
}
56+
}

sql/core/src/main/scala/org/apache/spark/sql/execution/python/AggregateInPandasExec.scala

Lines changed: 0 additions & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -22,7 +22,6 @@ import java.io.File
2222
import scala.collection.mutable.ArrayBuffer
2323

2424
import org.apache.spark.{SparkEnv, TaskContext}
25-
2625
import org.apache.spark.api.python.{ChainedPythonFunctions, PythonEvalType}
2726
import org.apache.spark.rdd.RDD
2827
import org.apache.spark.sql.catalyst.InternalRow

sql/core/src/main/scala/org/apache/spark/sql/execution/streaming/state/MultiValuesStateStoreRDD.scala

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -48,9 +48,9 @@ class MultiValuesStateStoreRDD[T: ClassTag, U: ClassTag](
4848
override protected def getPartitions: Array[Partition] = dataRDD.partitions
4949

5050
/**
51-
* Set the preferred location of each partition using the executor that has the related
52-
* [[StateStoreProvider]] already loaded.
53-
*/
51+
* Set the preferred location of each partition using the executor that has the related
52+
* [[StateStoreProvider]] already loaded.
53+
*/
5454
override def getPreferredLocations(partition: Partition): Seq[String] = {
5555
val stateStoreProviderId = StateStoreProviderId(
5656
StateStoreId(stateInfo.checkpointLocation, stateInfo.operatorId, partition.index),

sql/core/src/main/scala/org/apache/spark/sql/execution/streaming/statefulOperators.scala

Lines changed: 0 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -21,9 +21,6 @@ import java.util.UUID
2121
import java.util.concurrent.TimeUnit._
2222

2323
import scala.collection.JavaConverters._
24-
import scala.collection.mutable
25-
26-
import org.apache.spark.TaskContext
2724

2825
import org.apache.spark.rdd.RDD
2926
import org.apache.spark.sql.catalyst.InternalRow

sql/core/src/test/scala/org/apache/spark/sql/execution/streaming/MergingSortWithMultiValuesStateIteratorSuite.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -272,4 +272,4 @@ class MergingSortWithMultiValuesStateIteratorSuite extends SharedSQLContext {
272272
}
273273
StateStore.stop()
274274
}
275-
}
275+
}

0 commit comments

Comments
 (0)