Skip to content

Commit

Permalink
address review comment
Browse files Browse the repository at this point in the history
  • Loading branch information
kiszk committed Sep 13, 2018
1 parent aa45757 commit 53d1ba2
Show file tree
Hide file tree
Showing 3 changed files with 3 additions and 29 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -45,22 +45,13 @@ case class RunningCount(count: Long)

case class Result(key: Long, count: Int)

class FlatMapGroupsWithStateSuite extends StateStoreMetricsTest
with BeforeAndAfterAll {
class FlatMapGroupsWithStateSuite extends StateStoreMetricsTest {

import testImplicits._
import GroupStateImpl._
import GroupStateTimeout._
import FlatMapGroupsWithStateSuite._

override def afterAll(): Unit = {
try {
super.afterAll()
} finally {
StateStore.stop()
}
}

test("GroupState - get, exists, update, remove") {
var state: GroupStateImpl[String] = null

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -46,16 +46,7 @@ object FailureSingleton {
var firstTime = true
}

class StreamingAggregationSuite extends StateStoreMetricsTest
with BeforeAndAfterAll with Assertions {

override def afterAll(): Unit = {
try {
super.afterAll()
} finally {
StateStore.stop()
}
}
class StreamingAggregationSuite extends StateStoreMetricsTest with Assertions {

import testImplicits._

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,18 +26,10 @@ import org.apache.spark.sql.execution.streaming.state.StateStore
import org.apache.spark.sql.functions._
import org.apache.spark.sql.internal.SQLConf

class StreamingDeduplicationSuite extends StateStoreMetricsTest with BeforeAndAfterAll {
class StreamingDeduplicationSuite extends StateStoreMetricsTest {

import testImplicits._

override def afterAll(): Unit = {
try {
super.afterAll()
} finally {
StateStore.stop()
}
}

test("deduplicate with all columns") {
val inputData = MemoryStream[String]
val result = inputData.toDS().dropDuplicates()
Expand Down

0 comments on commit 53d1ba2

Please sign in to comment.