public class IOLoadTestBase extends LoadTestBase
Modifier and Type | Class and Description |
---|---|
static class |
IOLoadTestBase.CountingFn<T>
A utility DoFn that counts elements passed through.
|
static class |
IOLoadTestBase.PipelineMetricsType |
LoadTestBase.MetricsConfiguration
Modifier and Type | Field and Description |
---|---|
static java.lang.String |
BEAM_METRICS_NAMESPACE
Namespace for Beam provided pipeline metrics (set up by Metrics transform).
|
protected java.lang.String |
tempBucketName |
CREDENTIALS, CREDENTIALS_PROVIDER, monitoringClient, pipelineLauncher, pipelineOperator, project, region, testName, watcher
Constructor and Description |
---|
IOLoadTestBase() |
Modifier and Type | Method and Description |
---|---|
protected void |
exportMetrics(org.apache.beam.it.common.PipelineLauncher.LaunchInfo launchInfo,
LoadTestBase.MetricsConfiguration metricsConfig,
boolean exportToInfluxDB,
org.apache.beam.sdk.testutils.publishing.InfluxDBSettings influxDBSettings)
Exports test metrics to InfluxDB or BigQuery depending on the configuration.
|
static java.lang.String |
getBeamMetricsName(IOLoadTestBase.PipelineMetricsType metricstype,
java.lang.String metricsName)
Given a metrics name, return Beam metrics name.
|
org.apache.beam.it.common.PipelineLauncher |
launcher() |
void |
setUpBase() |
void |
tearDownBase() |
calculateAverage, createConfig, exportMetricsToBigQuery, getCpuUtilizationMetrics, getDataFreshnessMetrics, getMetrics, getMetrics, getMetrics, getMetrics, getSystemLatencyMetrics, getThroughputMetrics, getWorkerTimeInterval, setUp, setUpClass, tearDownLoadTestBase, waitForNumMessages
protected java.lang.String tempBucketName
public static final java.lang.String BEAM_METRICS_NAMESPACE
public void setUpBase()
public void tearDownBase() throws java.io.IOException
java.io.IOException
public org.apache.beam.it.common.PipelineLauncher launcher()
launcher
in class LoadTestBase
public static java.lang.String getBeamMetricsName(IOLoadTestBase.PipelineMetricsType metricstype, java.lang.String metricsName)
protected void exportMetrics(org.apache.beam.it.common.PipelineLauncher.LaunchInfo launchInfo, LoadTestBase.MetricsConfiguration metricsConfig, boolean exportToInfluxDB, org.apache.beam.sdk.testutils.publishing.InfluxDBSettings influxDBSettings)