Skip to content

Commit a33ea0d

Browse files
committed
removed constructor
1 parent 2e6899f commit a33ea0d

File tree

1 file changed

+5
-5
lines changed

1 file changed

+5
-5
lines changed

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

Lines changed: 5 additions & 5 deletions
Original file line numberDiff line numberDiff line change
@@ -29,7 +29,7 @@ import org.apache.spark.sql.expressions.Aggregator
2929
// This file defines internal implementations for aggregators.
3030
////////////////////////////////////////////////////////////////////////////////////////////////////
3131

32-
abstract class TypedAggregator[IN, BUF: TypeTag, OUT: TypeTag, FRESULT, JAVA](f: IN => FRESULT)
32+
abstract class TypedAggregator[IN, BUF: TypeTag, OUT: TypeTag, JAVA]
3333
extends Aggregator[IN, BUF, OUT] {
3434

3535
def bufferEncoder: Encoder[BUF] = ExpressionEncoder[BUF]()
@@ -41,7 +41,7 @@ abstract class TypedAggregator[IN, BUF: TypeTag, OUT: TypeTag, FRESULT, JAVA](f:
4141
}
4242

4343
class TypedSumDouble[IN](val f: IN => Double)
44-
extends TypedAggregator[IN, Double, Double, Double, java.lang.Double](f) {
44+
extends TypedAggregator[IN, Double, Double, java.lang.Double] {
4545

4646
override def zero: Double = 0.0
4747
override def reduce(b: Double, a: IN): Double = b + f(a)
@@ -54,7 +54,7 @@ class TypedSumDouble[IN](val f: IN => Double)
5454

5555

5656
class TypedSumLong[IN](val f: IN => Long)
57-
extends TypedAggregator[IN, Long, Long, Long, java.lang.Long](f) {
57+
extends TypedAggregator[IN, Long, Long, java.lang.Long] {
5858

5959
override def zero: Long = 0L
6060
override def reduce(b: Long, a: IN): Long = b + f(a)
@@ -66,7 +66,7 @@ class TypedSumLong[IN](val f: IN => Long)
6666
}
6767

6868
class TypedCount[IN](val f: IN => Any)
69-
extends TypedAggregator[IN, Long, Long, Any, java.lang.Long](f) {
69+
extends TypedAggregator[IN, Long, Long, java.lang.Long] {
7070

7171
override def zero: Long = 0
7272
override def reduce(b: Long, a: IN): Long = if (f(a) == null) b else b + 1
@@ -79,7 +79,7 @@ class TypedCount[IN](val f: IN => Any)
7979
}
8080

8181
class TypedAverage[IN](val f: IN => Double)
82-
extends TypedAggregator[IN, (Double, Long), Double, Double, java.lang.Double](f) {
82+
extends TypedAggregator[IN, (Double, Long), Double, java.lang.Double] {
8383

8484
override def zero: (Double, Long) = (0.0, 0L)
8585
override def reduce(b: (Double, Long), a: IN): (Double, Long) = (f(a) + b._1, 1 + b._2)

0 commit comments

Comments
 (0)