public class AsyncEventQueue extends Object implements SparkListenerBus, org.apache.spark.internal.Logging
Delivery will only begin when the start()
method is called. The stop()
method should be
called when no more events need to be delivered.
Constructor and Description |
---|
AsyncEventQueue(String name,
SparkConf conf,
org.apache.spark.scheduler.LiveListenerBusMetrics metrics,
org.apache.spark.scheduler.LiveListenerBus bus) |
Modifier and Type | Method and Description |
---|---|
static int |
LOGGING_INTERVAL() |
String |
name() |
static Object |
POISON_PILL() |
void |
post(SparkListenerEvent event) |
void |
removeListenerOnError(SparkListenerInterface listener)
This can be overridden by subclasses if there is any extra cleanup to do when removing a
listener.
|
boolean |
waitUntilEmpty(long deadline)
For testing only.
|
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
doPostEvent
addListener, findListenersByClass, isIgnorableException, listeners, postToAll, redactEvent, removeAllListeners, removeListener
$init$, initializeForcefully, initializeLogIfNecessary, initializeLogIfNecessary, initializeLogIfNecessary$default$2, initLock, isTraceEnabled, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning, org$apache$spark$internal$Logging$$log__$eq, org$apache$spark$internal$Logging$$log_, uninitialize
public AsyncEventQueue(String name, SparkConf conf, org.apache.spark.scheduler.LiveListenerBusMetrics metrics, org.apache.spark.scheduler.LiveListenerBus bus)
public static Object POISON_PILL()
public static int LOGGING_INTERVAL()
public String name()
public void post(SparkListenerEvent event)
public boolean waitUntilEmpty(long deadline)
deadline
- (undocumented)public void removeListenerOnError(SparkListenerInterface listener)
ListenerBus
removeListenerOnError
in interface ListenerBus<SparkListenerInterface,SparkListenerEvent>
listener
- (undocumented)