org.apache.spark.CheckpointCompressionSuite: checkpoint compression
|
7 ms |
|
org.apache.spark.CheckpointSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
43 ms |
|
org.apache.spark.JavaJdbcRDDSuite: testJavaJdbcRDD
|
5 ms |
|
org.apache.spark.SparkContextSuite: Cancelling job group should not cause SparkContext to shutdown (SPARK-6414)
|
2226 ms |
|
org.apache.spark.UnpersistSuite: unpersist RDD
|
1 ms |
|
org.apache.spark.deploy.LogUrlsStandaloneSuite: verify that correct log urls get propagated from workers
|
1 ms |
|
org.apache.spark.deploy.LogUrlsStandaloneSuite: verify that log urls reflect SPARK_PUBLIC_DNS (SPARK-6175)
|
2 ms |
|
org.apache.spark.deploy.history.HistoryServerSuite: incomplete apps get refreshed
|
114 ms |
|
org.apache.spark.deploy.history.HistoryServerSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
9219 ms |
|
org.apache.spark.launcher.SparkLauncherSuite: testInProcessLauncher
|
10054 ms |
|
org.apache.spark.metrics.InputOutputMetricsSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
51 ms |
|
org.apache.spark.rdd.LocalCheckpointSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
28 ms |
|
org.apache.spark.scheduler.PoolSuite: FIFO Scheduler Test
|
1 ms |
|
org.apache.spark.scheduler.PoolSuite: Fair Scheduler Test
|
1 ms |
|
org.apache.spark.scheduler.PoolSuite: Nested Pool Test
|
1 ms |
|
org.apache.spark.scheduler.PoolSuite: pool property
|
1 ms |
|
org.apache.spark.scheduler.PoolSuite: pool property is not set
|
0 ms |
|
org.apache.spark.scheduler.PoolSuite: pool property points to a non-existent pool
|
0 ms |
|
org.apache.spark.scheduler.PoolSuite: file property is set
|
1 ms |
|
org.apache.spark.scheduler.PoolSuite: file property is not set
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: TaskSet with no preferences
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: multiple offers with no preferences
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: skip unsatisfiable locality levels
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: basic delay scheduling
|
22 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: we do not need to delay scheduling when we only have noPref tasks in the queue
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: delay scheduling with fallback
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: delay scheduling with failed hosts
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: task result lost
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: repeated failures lead to task set abortion
|
41 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: executors should be blacklisted after task failure, in spite of locality preferences
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: new executors get added and lost
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: Executors exit for reason unrelated to currently running tasks
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: test RACK_LOCAL tasks
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: do not emit warning when serialized task is small
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: emit warning when serialized task is large
|
3 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: Not serializable exception thrown if the task cannot be serialized
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: abort the job if total size of results is too large
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: [SPARK-13931] taskSetManager should not send Resubmitted tasks after being a zombie
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: [SPARK-22074] Task killed by other attempt task should not be resubmitted
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: speculative and noPref task should be scheduled after node-local
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: node-local tasks should be scheduled right away when there are only node-local and no-preference tasks
|
6 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: SPARK-4939: node-local tasks should be scheduled right after process-local tasks finished
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: SPARK-4939: no-pref tasks should be scheduled after process-local tasks finished
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: Ensure TaskSetManager is usable after addition of levels
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: Test that locations with HDFSCacheTaskLocation are treated as PROCESS_LOCAL
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: Kill other task attempts when one attempt belonging to the same task succeeds
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: Killing speculative tasks does not count towards aborting the taskset
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: SPARK-19868: DagScheduler only notified of taskEnd when state is ready
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: SPARK-17894: Verify TaskSetManagers for different stage attempts have unique names
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: don't update blacklist for shuffle-fetch failures, preemption, denied commits, or killed tasks
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: update application blacklist for shuffle-fetch
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: update blacklist before adding pending task to avoid race condition
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: SPARK-21563 context's added jars shouldn't change mid-TaskSet
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: [SPARK-24677] Avoid NoSuchElementException from MedianHeap
|
0 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: SPARK-24755 Executor loss can cause task to not be resubmitted
|
1 ms |
|
org.apache.spark.scheduler.TaskSetManagerSuite: SPARK-13343 speculative tasks that didn't commit shouldn't be marked as success
|
1 ms |
|
org.apache.spark.shuffle.BlockStoreShuffleReaderSuite: read() releases resources on completion
|
1 ms |
|
org.apache.spark.shuffle.ShuffleDependencySuite: key, value, and combiner classes correct in shuffle dependency without aggregation
|
1 ms |
|
org.apache.spark.shuffle.ShuffleDependencySuite: key, value, and combiner classes available in shuffle dependency with aggregation
|
0 ms |
|
org.apache.spark.shuffle.ShuffleDependencySuite: combineByKey null combiner class tag handled correctly
|
0 ms |
|
org.apache.spark.storage.BlockManagerBasicStrategyReplicationSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
65 ms |
|
org.apache.spark.storage.BlockManagerProactiveReplicationSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
61 ms |
|
org.apache.spark.storage.BlockManagerReplicationSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
60 ms |
|
org.apache.spark.storage.DiskBlockManagerSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
51 ms |
|
org.apache.spark.util.collection.ExternalSorterSuite: sort without breaking sorting contracts with java ser
|
1 ms |
|
org.apache.spark.util.collection.ExternalSorterSuite: spilling with hash collisions
|
1 ms |
|
org.apache.spark.util.collection.ExternalSorterSuite: spilling with many hash collisions
|
1 ms |
|
org.apache.spark.util.collection.ExternalSorterSuite: MaxValue key
|
1 ms |
|
org.apache.spark.util.collection.ExternalSorterSuite: spilling with null keys and values
|
17 ms |
|
org.apache.spark.util.collection.ExternalSorterSuite: sorting updates peak execution memory
|
0 ms |
|
org.apache.spark.util.collection.ExternalSorterSuite: force to spill for external sorter
|
0 ms |
|
org.apache.spark.utils.PeriodicRDDCheckpointerSuite: (It is not a test it is a sbt.testing.SuiteSelector)
|
33 ms |
|
test.org.apache.spark.Java8RDDAPISuite: leftOuterJoin
|
2 ms |
|
test.org.apache.spark.Java8RDDAPISuite: foldReduce
|
0 ms |
|
test.org.apache.spark.Java8RDDAPISuite: mapsFromPairsToPairs
|
1 ms |
|
test.org.apache.spark.Java8RDDAPISuite: flatMap
|
1 ms |
|
test.org.apache.spark.Java8RDDAPISuite: foreach
|
3 ms |
|
test.org.apache.spark.Java8RDDAPISuite: map
|
1 ms |
|
test.org.apache.spark.Java8RDDAPISuite: zip
|
0 ms |
|
test.org.apache.spark.Java8RDDAPISuite: keyBy
|
0 ms |
|
test.org.apache.spark.Java8RDDAPISuite: groupBy
|
1 ms |
|
test.org.apache.spark.Java8RDDAPISuite: mapPartitions
|
1 ms |
|
test.org.apache.spark.Java8RDDAPISuite: foldByKey
|
0 ms |
|
test.org.apache.spark.Java8RDDAPISuite: mapOnPairRDD
|
1 ms |
|
test.org.apache.spark.Java8RDDAPISuite: sequenceFile
|
1 ms |
|
test.org.apache.spark.Java8RDDAPISuite: collectPartitions
|
0 ms |
|
test.org.apache.spark.Java8RDDAPISuite: reduceByKey
|
0 ms |
|
test.org.apache.spark.Java8RDDAPISuite: foreachWithAnonymousClass
|
2 ms |
|
test.org.apache.spark.Java8RDDAPISuite: collectAsMapWithIntArrayValues
|
14 ms |
|
test.org.apache.spark.Java8RDDAPISuite: zipPartitions
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: groupByOnPairRDD
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: binaryFilesCaching
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: sparkContextUnion
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: checkpointAndComputation
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: leftOuterJoin
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: keyByOnPairRDD
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: getNumPartitions
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: wholeTextFiles
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: binaryFiles
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: foldReduce
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: writeWithNewAPIHadoopFile
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: hadoopFile
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: lookup
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: countAsync
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: textFiles
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: binaryRecords
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: toLocalIterator
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: repartitionAndSortWithinPartitions
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: reduce
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: sample
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: sortBy
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: mapsFromPairsToPairs
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: flatMap
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: cogroup3
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: cogroup4
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: randomSplit
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: persist
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: foreach
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: hadoopFileCompressed
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: accumulators
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: textFilesCompressed
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: testAsyncActionCancellation
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: checkpointAndRestore
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: sortByKey
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: aggregateByKey
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: map
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: max
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: min
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: top
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: zip
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: fold
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: glom
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: take
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: javaDoubleRDDHistoGram
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: collectUnderlyingScalaRDD
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: keyBy
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: mapPartitionsWithIndex
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: sampleByKey
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: intersection
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: aggregate
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: cartesian
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: countApproxDistinctByKey
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: readWithNewAPIHadoopFile
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: testRegisterKryoClasses
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: groupBy
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: sampleByKeyExact
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: mapPartitions
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: takeOrdered
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: foldByKey
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: objectFilesOfInts
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: treeAggregate
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: testGetPersistentRDDs
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: approximateResults
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: treeReduce
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: collectAsMapAndSerialize
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: countApproxDistinct
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: javaDoubleRDD
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: mapOnPairRDD
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: testAsyncActionErrorWrapping
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: naturalMax
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: naturalMin
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: sequenceFile
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: collectPartitions
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: cogroup
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: reduceByKey
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: repartition
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: iterator
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: emptyRDD
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: zipWithIndex
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: foreachPartition
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: combineByKey
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: takeAsync
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: collectAsMapWithIntArrayValues
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: objectFilesOfComplexTypes
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: zipWithUniqueId
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: collectAsync
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: foreachAsync
|
1 ms |
|
test.org.apache.spark.JavaAPISuite: zipPartitions
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: reduceOnJavaDoubleRDD
|
0 ms |
|
test.org.apache.spark.JavaAPISuite: isEmpty
|
0 ms |
|
test.org.apache.spark.JavaSparkContextSuite: javaSparkContext
|
4 ms |
|
test.org.apache.spark.JavaSparkContextSuite: scalaSparkContext
|
1 ms |
|