| Interface | Description |
|---|---|
| ActorLogReceive |
A trait to enable logging all Akka actor messages.
|
| Clock |
An interface to represent clocks, so that they can be mocked out in unit tests.
|
| ListenerBus<L,E> |
An event bus which posts events to its listeners.
|
| TaskCompletionListener |
:: DeveloperApi ::
|
| Class | Description |
|---|---|
| AkkaUtils |
Various utility classes for working with Akka.
|
| AsynchronousListenerBus<L,E> |
Asynchronously passes events to registered listeners.
|
| BoundedPriorityQueue<A> |
Bounded priority queue.
|
| ByteBufferInputStream |
Reads data from a ByteBuffer, and optionally cleans it up using BlockManager.dispose()
at the end of the stream (e.g.
|
| CallSite |
CallSite represents a place in user code.
|
| ChildFirstURLClassLoader |
A mutable class loader that gives preference to its own URLs over the parent class loader
when loading classes and resources.
|
| ClosureCleaner | |
| CollectionsUtils | |
| CompletionIterator<A,I extends scala.collection.Iterator<A>> |
Wrapper around an iterator which calls a completion method after it successfully iterates
through all the elements.
|
| Distribution |
Util for getting some stats from a small sample of numeric values, with some handy
summary functions.
|
| EventLoop<E> |
An event loop to receive events from the caller and process all events in the event thread.
|
| FieldAccessFinder | |
| IdGenerator |
A util used to get a unique generation ID.
|
| InnerClosureFinder | |
| IntParam |
An extractor object for parsing strings into integers.
|
| JsonProtocol |
Serializes SparkListener events to/from JSON.
|
| ManualClock |
A
Clock whose time can be manually set and modified. |
| MemoryParam |
An extractor object for parsing JVM memory strings, such as "10g", into an Int representing
the number of megabytes.
|
| MetadataCleaner |
Runs a timer task to periodically clean up metadata (e.g.
|
| MetadataCleanerType | |
| MutablePair<T1,T2> |
:: DeveloperApi ::
A tuple of 2 elements.
|
| MutableURLClassLoader |
URL class loader that exposes the
addURL and getURLs methods in URLClassLoader. |
| NextIterator<U> |
Provides a basic/boilerplate Iterator implementation.
|
| ParentClassLoader |
A class loader which makes some protected methods in ClassLoader accesible.
|
| RedirectThread |
A utility class to redirect the child process's stdout or stderr.
|
| ReturnStatementFinder | |
| SerializableBuffer |
A wrapper around a java.nio.ByteBuffer that is serializable through Java serialization, to make
it easier to pass ByteBuffers in case class messages.
|
| SignalLogger |
Used to log signals received.
|
| SignalLoggerHandler | |
| SizeEstimator |
Estimates the sizes of Java objects (number of bytes of memory they occupy), for use in
memory-aware caches.
|
| SparkExitCode | |
| SparkUncaughtExceptionHandler |
The default uncaught exception handler for Executors terminates the whole process, to avoid
getting into a bad state indefinitely.
|
| StatCounter |
A class for tracking the statistics of a set of numbers (count, mean and variance) in a
numerically robust way.
|
| SystemClock |
A clock backed by the actual time from the OS as reported by the
System API. |
| ThreadStackTrace |
Used for shipping per-thread stacktraces from the executors to driver.
|
| TimeStampedHashMap<A,B> |
This is a custom implementation of scala.collection.mutable.Map which stores the insertion
timestamp along with each key-value pair.
|
| TimeStampedHashSet<A> | |
| TimeStampedValue<V> | |
| TimeStampedWeakValueHashMap<A,B> |
A wrapper of TimeStampedHashMap that ensures the values are weakly referenced and timestamped.
|
| Utils |
Various utility methods used by Spark.
|
| Vector | |
| Vector.Multiplier | |
| Vector.VectorAccumParam$ |
| Exception | Description |
|---|---|
| TaskCompletionListenerException |
Exception thrown when there is an exception in
executing the callback in TaskCompletionListener.
|