Class MetricsAccumulator
java.lang.Object
org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>
 
org.apache.beam.runners.spark.structuredstreaming.metrics.MetricsAccumulator
- All Implemented Interfaces:
 Serializable,scala.Serializable
public class MetricsAccumulator
extends org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> 
AccumulatorV2 for Beam metrics captured in MetricsContainerStepMap.- See Also:
 
- 
Constructor Summary
Constructors - 
Method Summary
Modifier and TypeMethodDescriptionvoidadd(org.apache.beam.runners.core.metrics.MetricsContainerStepMap other) static voidclear()copy()static MetricsAccumulatorgetInstance(org.apache.spark.sql.SparkSession session) Get theMetricsAccumulatoron this driver.booleanisZero()voidmerge(org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap, org.apache.beam.runners.core.metrics.MetricsContainerStepMap> other) voidreset()org.apache.beam.runners.core.metrics.MetricsContainerStepMapvalue()Methods inherited from class org.apache.spark.util.AccumulatorV2
copyAndReset, countFailedValues, id, isAtDriverSide, isRegistered, metadata, metadata_$eq, name, register, register$default$2, register$default$3, toInfo, toString, withBufferSerialized, writeReplace 
- 
Constructor Details
- 
MetricsAccumulator
public MetricsAccumulator() 
 - 
 - 
Method Details
- 
isZero
public boolean isZero()- Specified by:
 isZeroin classorg.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> 
 - 
copy
- Specified by:
 copyin classorg.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> 
 - 
reset
public void reset()- Specified by:
 resetin classorg.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> 
 - 
add
public void add(org.apache.beam.runners.core.metrics.MetricsContainerStepMap other) - Specified by:
 addin classorg.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> 
 - 
merge
public void merge(org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap, org.apache.beam.runners.core.metrics.MetricsContainerStepMap> other) - Specified by:
 mergein classorg.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> 
 - 
value
public org.apache.beam.runners.core.metrics.MetricsContainerStepMap value()- Specified by:
 valuein classorg.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> 
 - 
getInstance
Get theMetricsAccumulatoron this driver. If there's no such accumulator yet, it will be created and registered using the providedSparkSession. - 
clear
public static void clear() 
 -