public class MetricsContainerStepMapAccumulator
extends org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>
AccumulatorV2
implementation for MetricsContainerStepMap
.Constructor and Description |
---|
MetricsContainerStepMapAccumulator(org.apache.beam.runners.core.metrics.MetricsContainerStepMap value) |
Modifier and Type | Method and Description |
---|---|
void |
add(org.apache.beam.runners.core.metrics.MetricsContainerStepMap other) |
MetricsContainerStepMapAccumulator |
copy() |
boolean |
isZero() |
void |
merge(org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> other) |
void |
reset() |
org.apache.beam.runners.core.metrics.MetricsContainerStepMap |
value() |
public MetricsContainerStepMapAccumulator(org.apache.beam.runners.core.metrics.MetricsContainerStepMap value)
public boolean isZero()
isZero
in class org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>
public MetricsContainerStepMapAccumulator copy()
copy
in class org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>
public void reset()
reset
in class org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>
public void add(org.apache.beam.runners.core.metrics.MetricsContainerStepMap other)
add
in class org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>
public void merge(org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap> other)
merge
in class org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>
public org.apache.beam.runners.core.metrics.MetricsContainerStepMap value()
value
in class org.apache.spark.util.AccumulatorV2<org.apache.beam.runners.core.metrics.MetricsContainerStepMap,org.apache.beam.runners.core.metrics.MetricsContainerStepMap>