package util
- Alphabetic
- By Inheritance
- util
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Type Members
- abstract class AccumulatorV2[IN, OUT] extends Serializable
The base class for accumulators, that can accumulate inputs of type
IN
, and produce output of typeOUT
.The base class for accumulators, that can accumulate inputs of type
IN
, and produce output of typeOUT
.OUT
should be a type that can be read atomically (e.g., Int, Long), or thread-safely (e.g., synchronized collections) because it will be read from other threads. - class ChildFirstURLClassLoader extends MutableURLClassLoader
A mutable class loader that gives preference to its own URLs over the parent class loader when loading classes and resources.
- class CollectionAccumulator[T] extends AccumulatorV2[T, List[T]]
An accumulator for collecting a list of elements.
An accumulator for collecting a list of elements.
- Since
2.0.0
- class DayTimeIntervalUtils extends AnyRef
- class DoubleAccumulator extends AccumulatorV2[Double, Double]
An accumulator for computing sum, count, and averages for double precision floating numbers.
An accumulator for computing sum, count, and averages for double precision floating numbers.
- Since
2.0.0
- class EnumUtil extends AnyRef
- Annotations
- @Private()
- class LongAccumulator extends AccumulatorV2[Long, Long]
An accumulator for computing sum, count, and average of 64-bit integers.
An accumulator for computing sum, count, and average of 64-bit integers.
- Since
2.0.0
- case class MutablePair[T1, T2](_1: T1, _2: T2) extends Product2[T1, T2] with Product with Serializable
:: DeveloperApi :: A tuple of 2 elements.
:: DeveloperApi :: A tuple of 2 elements. This can be used as an alternative to Scala's Tuple2 when we want to minimize object allocation.
- _1
Element 1 of this MutablePair
- _2
Element 2 of this MutablePair
- Annotations
- @DeveloperApi()
- class MutableURLClassLoader extends URLClassLoader
URL class loader that exposes the
addURL
method in URLClassLoader. - class ParentClassLoader extends ClassLoader
A class loader which makes some protected methods in ClassLoader accessible.
- class SerializableConfiguration extends Serializable
Hadoop configuration but serializable.
Hadoop configuration but serializable. Use
value
to access the Hadoop configuration.- Annotations
- @DeveloperApi() @Unstable()
- trait SparkTestUtils extends AnyRef
- class StatCounter extends Serializable
A class for tracking the statistics of a set of numbers (count, mean and variance) in a numerically robust way.
A class for tracking the statistics of a set of numbers (count, mean and variance) in a numerically robust way. Includes support for merging two StatCounters. Based on Welford and Chan's algorithms for running variance.
- trait TaskCompletionListener extends EventListener
:: DeveloperApi ::
:: DeveloperApi ::
Listener providing a callback function to invoke when a task's execution completes.
- Annotations
- @DeveloperApi()
- trait TaskFailureListener extends EventListener
:: DeveloperApi ::
:: DeveloperApi ::
Listener providing a callback function to invoke when a task's execution encounters an error. Operations defined here must be idempotent, as
onTaskFailure
can be called multiple times.- Annotations
- @DeveloperApi()
- class YearMonthIntervalUtils extends AnyRef
Value Members
- object LogUtils
:: : DeveloperApi :: Utils for querying Spark logs with Spark SQL.
:: : DeveloperApi :: Utils for querying Spark logs with Spark SQL.
- Annotations
- @DeveloperApi()
- Since
4.0.0
- object SizeEstimator extends Logging
:: DeveloperApi :: Estimates the sizes of Java objects (number of bytes of memory they occupy), for use in memory-aware caches.
:: DeveloperApi :: Estimates the sizes of Java objects (number of bytes of memory they occupy), for use in memory-aware caches.
Based on the following JavaWorld article: https://www.infoworld.com/article/2077408/sizeof-for-java.html
- Annotations
- @DeveloperApi()
- object SparkEnvUtils extends SparkEnvUtils
- object SparkTestUtils extends SparkTestUtils
- object StatCounter extends Serializable