public class StatsReportListener extends Object implements StreamingListener
Constructor and Description |
---|
StatsReportListener(int numBatchInfos) |
Modifier and Type | Method and Description |
---|---|
scala.collection.mutable.Queue<BatchInfo> |
batchInfos() |
scala.Option<org.apache.spark.util.Distribution> |
extractDistribution(scala.Function1<BatchInfo,scala.Option<Object>> getMetric) |
void |
onBatchCompleted(StreamingListenerBatchCompleted batchStarted)
Called when processing of a batch of jobs has completed.
|
void |
printStats() |
void |
showMillisDistribution(String heading,
scala.Function1<BatchInfo,scala.Option<Object>> getMetric) |
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
onBatchStarted, onBatchSubmitted, onOutputOperationCompleted, onOutputOperationStarted, onReceiverError, onReceiverStarted, onReceiverStopped, onStreamingStarted
public scala.collection.mutable.Queue<BatchInfo> batchInfos()
public void onBatchCompleted(StreamingListenerBatchCompleted batchStarted)
StreamingListener
onBatchCompleted
in interface StreamingListener
public void printStats()
public void showMillisDistribution(String heading, scala.Function1<BatchInfo,scala.Option<Object>> getMetric)
public scala.Option<org.apache.spark.util.Distribution> extractDistribution(scala.Function1<BatchInfo,scala.Option<Object>> getMetric)