Search in sources :

Example 1 with SimpleMonitoringInfoBuilder

use of org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder in project flink by apache.

the class FlinkMetricContainerTest method testCounterMonitoringInfoUpdate.

@Test
public void testCounterMonitoringInfoUpdate() {
    SimpleCounter userCounter = new SimpleCounter();
    when(metricGroup.counter("myCounter")).thenReturn(userCounter);
    MonitoringInfo userMonitoringInfo = new SimpleMonitoringInfoBuilder().setUrn(MonitoringInfoConstants.Urns.USER_SUM_INT64).setLabel(MonitoringInfoConstants.Labels.NAMESPACE, DEFAULT_NAMESPACE).setLabel(MonitoringInfoConstants.Labels.NAME, "myCounter").setLabel(MonitoringInfoConstants.Labels.PTRANSFORM, "anyPTransform").setInt64SumValue(111).build();
    assertThat(userCounter.getCount(), is(0L));
    container.updateMetrics("step", ImmutableList.of(userMonitoringInfo));
    assertThat(userCounter.getCount(), is(111L));
}
Also used : SimpleCounter(org.apache.flink.metrics.SimpleCounter) MonitoringInfo(org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo) SimpleMonitoringInfoBuilder(org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder) MetricGroupTest(org.apache.flink.runtime.metrics.groups.MetricGroupTest) Test(org.junit.Test)

Example 2 with SimpleMonitoringInfoBuilder

use of org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder in project flink by apache.

the class FlinkMetricContainerTest method testGaugeMonitoringInfoUpdate.

@Test
public void testGaugeMonitoringInfoUpdate() {
    MonitoringInfo userMonitoringInfo = new SimpleMonitoringInfoBuilder().setUrn(MonitoringInfoConstants.Urns.USER_SUM_INT64).setLabel(MonitoringInfoConstants.Labels.NAMESPACE, DEFAULT_NAMESPACE).setLabel(MonitoringInfoConstants.Labels.NAME, "myGauge").setLabel(MonitoringInfoConstants.Labels.PTRANSFORM, "anyPTransform").setInt64LatestValue(GaugeData.create(111L)).build();
    container.updateMetrics("step", ImmutableList.of(userMonitoringInfo));
    verify(metricGroup).gauge(eq("myGauge"), argThat((ArgumentMatcher<FlinkMetricContainer.FlinkGauge>) argument -> {
        Long actual = argument.getValue();
        return actual.equals(111L);
    }));
}
Also used : MonitoringInfo(org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo) SimpleMonitoringInfoBuilder(org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder) ArgumentMatcher(org.mockito.ArgumentMatcher) MetricGroupTest(org.apache.flink.runtime.metrics.groups.MetricGroupTest) Test(org.junit.Test)

Example 3 with SimpleMonitoringInfoBuilder

use of org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder in project flink by apache.

the class FlinkMetricContainerTest method testMeterMonitoringInfoUpdate.

@Test
public void testMeterMonitoringInfoUpdate() {
    MeterView userMeter = new MeterView(new SimpleCounter());
    when(metricGroup.meter(eq("myMeter"), any(Meter.class))).thenReturn(userMeter);
    String namespace = "[\"key\", \"value\", \"MetricGroupType.key\", \"MetricGroupType.value\", \"60\"]";
    MonitoringInfo userMonitoringInfo = new SimpleMonitoringInfoBuilder().setUrn(MonitoringInfoConstants.Urns.USER_SUM_INT64).setLabel(MonitoringInfoConstants.Labels.NAMESPACE, namespace).setLabel(MonitoringInfoConstants.Labels.NAME, "myMeter").setLabel(MonitoringInfoConstants.Labels.PTRANSFORM, "anyPTransform").setInt64SumValue(111).build();
    assertThat(userMeter.getCount(), is(0L));
    assertThat(userMeter.getRate(), is(0.0));
    container.updateMetrics("step", ImmutableList.of(userMonitoringInfo));
    userMeter.update();
    assertThat(userMeter.getCount(), is(111L));
    // 111 div 60 = 1.85
    assertThat(userMeter.getRate(), is(1.85));
}
Also used : SimpleCounter(org.apache.flink.metrics.SimpleCounter) MonitoringInfo(org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo) SimpleMonitoringInfoBuilder(org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder) Meter(org.apache.flink.metrics.Meter) MeterView(org.apache.flink.metrics.MeterView) MetricGroupTest(org.apache.flink.runtime.metrics.groups.MetricGroupTest) Test(org.junit.Test)

Example 4 with SimpleMonitoringInfoBuilder

use of org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder in project flink by apache.

the class FlinkMetricContainerTest method testDistributionMonitoringInfoUpdate.

@Test
public void testDistributionMonitoringInfoUpdate() {
    MonitoringInfo userMonitoringInfo = new SimpleMonitoringInfoBuilder().setUrn(MonitoringInfoConstants.Urns.USER_DISTRIBUTION_INT64).setLabel(MonitoringInfoConstants.Labels.NAMESPACE, DEFAULT_NAMESPACE).setLabel(MonitoringInfoConstants.Labels.NAME, "myDistribution").setLabel(MonitoringInfoConstants.Labels.PTRANSFORM, "anyPTransform").setInt64DistributionValue(DistributionData.create(30, 10, 1, 5)).build();
    container.updateMetrics("step", ImmutableList.of(userMonitoringInfo));
    // The one Flink distribution that gets created is a FlinkDistributionGauge; here we verify
    // its initial (and in this test, final) value
    verify(metricGroup).gauge(eq("myDistribution"), argThat((ArgumentMatcher<FlinkMetricContainer.FlinkDistributionGauge>) argument -> {
        DistributionResult actual = argument.getValue();
        DistributionResult expected = DistributionResult.create(30, 10, 1, 5);
        return actual.equals(expected);
    }));
}
Also used : DistributionResult(org.apache.beam.sdk.metrics.DistributionResult) MonitoringInfo(org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo) SimpleMonitoringInfoBuilder(org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder) ArgumentMatcher(org.mockito.ArgumentMatcher) MetricGroupTest(org.apache.flink.runtime.metrics.groups.MetricGroupTest) Test(org.junit.Test)

Example 5 with SimpleMonitoringInfoBuilder

use of org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder in project beam by apache.

the class PCollectionConsumerRegistryTest method testLazyByteSizeEstimation.

@Test
public void testLazyByteSizeEstimation() throws Exception {
    final String pCollectionA = "pCollectionA";
    final String pTransformIdA = "pTransformIdA";
    MetricsContainerStepMap metricsContainerRegistry = new MetricsContainerStepMap();
    PCollectionConsumerRegistry consumers = new PCollectionConsumerRegistry(metricsContainerRegistry, mock(ExecutionStateTracker.class));
    FnDataReceiver<WindowedValue<Iterable<String>>> consumerA1 = mock(FnDataReceiver.class);
    consumers.register(pCollectionA, pTransformIdA, consumerA1, IterableCoder.of(StringUtf8Coder.of()));
    FnDataReceiver<WindowedValue<Iterable<String>>> wrapperConsumer = (FnDataReceiver<WindowedValue<Iterable<String>>>) (FnDataReceiver) consumers.getMultiplexingConsumer(pCollectionA);
    String elementValue = "elem";
    long elementByteSize = StringUtf8Coder.of().getEncodedElementByteSize(elementValue);
    WindowedValue<Iterable<String>> element = valueInGlobalWindow(new TestElementByteSizeObservableIterable<>(Arrays.asList(elementValue, elementValue), elementByteSize));
    int numElements = 10;
    // Mock doing work on the iterable items
    doAnswer((Answer<Void>) invocation -> {
        Object[] args = invocation.getArguments();
        WindowedValue<Iterable<String>> arg = (WindowedValue<Iterable<String>>) args[0];
        Iterator it = arg.getValue().iterator();
        while (it.hasNext()) {
            it.next();
        }
        return null;
    }).when(consumerA1).accept(element);
    for (int i = 0; i < numElements; i++) {
        wrapperConsumer.accept(element);
    }
    // Check that the underlying consumers are each invoked per element.
    verify(consumerA1, times(numElements)).accept(element);
    assertThat(consumers.keySet(), contains(pCollectionA));
    List<MonitoringInfo> expected = new ArrayList<>();
    SimpleMonitoringInfoBuilder builder = new SimpleMonitoringInfoBuilder();
    builder.setUrn(MonitoringInfoConstants.Urns.ELEMENT_COUNT);
    builder.setLabel(MonitoringInfoConstants.Labels.PCOLLECTION, pCollectionA);
    builder.setInt64SumValue(numElements);
    expected.add(builder.build());
    builder = new SimpleMonitoringInfoBuilder();
    builder.setUrn(Urns.SAMPLED_BYTE_SIZE);
    builder.setLabel(MonitoringInfoConstants.Labels.PCOLLECTION, pCollectionA);
    long expectedBytes = (elementByteSize + 1) * 2 + // Additional 5 bytes are due to size and hasNext = false (1 byte).
    5;
    builder.setInt64DistributionValue(DistributionData.create(numElements * expectedBytes, numElements, expectedBytes, expectedBytes));
    expected.add(builder.build());
    // Clear the timestamp before comparison.
    Iterable<MonitoringInfo> result = Iterables.filter(metricsContainerRegistry.getMonitoringInfos(), monitoringInfo -> monitoringInfo.containsLabels(Labels.PCOLLECTION));
    assertThat(result, containsInAnyOrder(expected.toArray()));
}
Also used : Arrays(java.util.Arrays) ExecutionStateTracker(org.apache.beam.runners.core.metrics.ExecutionStateTracker) MonitoringInfoMetricName(org.apache.beam.runners.core.metrics.MonitoringInfoMetricName) WindowedValue(org.apache.beam.sdk.util.WindowedValue) PowerMockito.mockStatic(org.powermock.api.mockito.PowerMockito.mockStatic) DistributionData(org.apache.beam.runners.core.metrics.DistributionData) Urns(org.apache.beam.runners.core.metrics.MonitoringInfoConstants.Urns) RunWith(org.junit.runner.RunWith) WindowedValue.valueInGlobalWindow(org.apache.beam.sdk.util.WindowedValue.valueInGlobalWindow) HashMap(java.util.HashMap) ArrayList(java.util.ArrayList) StringUtf8Coder(org.apache.beam.sdk.coders.StringUtf8Coder) ElementByteSizeObservableIterable(org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable) Mockito.doThrow(org.mockito.Mockito.doThrow) Answer(org.mockito.stubbing.Answer) MetricsContainerStepMap(org.apache.beam.runners.core.metrics.MetricsContainerStepMap) ElementByteSizeObservableIterator(org.apache.beam.sdk.util.common.ElementByteSizeObservableIterator) Mockito.doAnswer(org.mockito.Mockito.doAnswer) SimpleMonitoringInfoBuilder(org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder) Iterables(org.apache.beam.vendor.guava.v26_0_jre.com.google.common.collect.Iterables) PrepareForTest(org.powermock.core.classloader.annotations.PrepareForTest) MonitoringInfoConstants(org.apache.beam.runners.core.metrics.MonitoringInfoConstants) MatcherAssert.assertThat(org.hamcrest.MatcherAssert.assertThat) PowerMockRunner(org.powermock.modules.junit4.PowerMockRunner) ExpectedException(org.junit.rules.ExpectedException) PowerMockito(org.powermock.api.mockito.PowerMockito) MonitoringInfo(org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo) Iterator(java.util.Iterator) IterableCoder(org.apache.beam.sdk.coders.IterableCoder) FnDataReceiver(org.apache.beam.sdk.fn.data.FnDataReceiver) Assert.assertTrue(org.junit.Assert.assertTrue) Mockito.times(org.mockito.Mockito.times) Test(org.junit.Test) Mockito.verify(org.mockito.Mockito.verify) MetricsEnvironment(org.apache.beam.sdk.metrics.MetricsEnvironment) List(java.util.List) Rule(org.junit.Rule) Matchers.contains(org.hamcrest.Matchers.contains) Matchers.containsInAnyOrder(org.hamcrest.Matchers.containsInAnyOrder) HandlesSplits(org.apache.beam.fn.harness.HandlesSplits) Labels(org.apache.beam.runners.core.metrics.MonitoringInfoConstants.Labels) Mockito.withSettings(org.mockito.Mockito.withSettings) Mockito.any(org.mockito.Mockito.any) Assert.assertEquals(org.junit.Assert.assertEquals) Mockito.mock(org.mockito.Mockito.mock) MetricsContainerStepMap(org.apache.beam.runners.core.metrics.MetricsContainerStepMap) FnDataReceiver(org.apache.beam.sdk.fn.data.FnDataReceiver) ElementByteSizeObservableIterable(org.apache.beam.sdk.util.common.ElementByteSizeObservableIterable) MonitoringInfo(org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo) ArrayList(java.util.ArrayList) SimpleMonitoringInfoBuilder(org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder) ExecutionStateTracker(org.apache.beam.runners.core.metrics.ExecutionStateTracker) WindowedValue(org.apache.beam.sdk.util.WindowedValue) ElementByteSizeObservableIterator(org.apache.beam.sdk.util.common.ElementByteSizeObservableIterator) Iterator(java.util.Iterator) PrepareForTest(org.powermock.core.classloader.annotations.PrepareForTest) Test(org.junit.Test)

Aggregations

SimpleMonitoringInfoBuilder (org.apache.beam.runners.core.metrics.SimpleMonitoringInfoBuilder)10 Test (org.junit.Test)10 MonitoringInfo (org.apache.beam.model.pipeline.v1.MetricsApi.MonitoringInfo)9 WindowedValue (org.apache.beam.sdk.util.WindowedValue)4 SimpleCounter (org.apache.flink.metrics.SimpleCounter)4 MetricGroupTest (org.apache.flink.runtime.metrics.groups.MetricGroupTest)4 ArrayList (java.util.ArrayList)3 ExecutionStateTracker (org.apache.beam.runners.core.metrics.ExecutionStateTracker)3 MetricsContainerStepMap (org.apache.beam.runners.core.metrics.MetricsContainerStepMap)3 FnDataReceiver (org.apache.beam.sdk.fn.data.FnDataReceiver)3 ArgumentMatcher (org.mockito.ArgumentMatcher)3 PrepareForTest (org.powermock.core.classloader.annotations.PrepareForTest)3 HashMap (java.util.HashMap)2 DistributionData (org.apache.beam.runners.core.metrics.DistributionData)2 StringUtf8Coder (org.apache.beam.sdk.coders.StringUtf8Coder)2 DistributionResult (org.apache.beam.sdk.metrics.DistributionResult)2 Arrays (java.util.Arrays)1 Iterator (java.util.Iterator)1 List (java.util.List)1 ConcurrentHashMap (java.util.concurrent.ConcurrentHashMap)1