Search in sources :

Example 1 with LoggedEvent

use of io.camunda.zeebe.logstreams.log.LoggedEvent in project zeebe-process-test by camunda.

the class RecordStreamSourceImpl method updateWithNewRecords.

private void updateWithNewRecords() {
    synchronized (logStreamReader) {
        if (lastPosition < 0) {
            logStreamReader.seekToFirstEvent();
        } else {
            logStreamReader.seekToNextEvent(lastPosition);
        }
        while (logStreamReader.hasNext()) {
            final LoggedEvent event = logStreamReader.next();
            final CopiedRecord<UnifiedRecordValue> record = mapToRecord(event);
            records.add(record);
            lastPosition = event.getPosition();
        }
    }
}
Also used : LoggedEvent(io.camunda.zeebe.logstreams.log.LoggedEvent) UnifiedRecordValue(io.camunda.zeebe.protocol.impl.record.UnifiedRecordValue)

Example 2 with LoggedEvent

use of io.camunda.zeebe.logstreams.log.LoggedEvent in project zeebe by camunda.

the class TypedEventSerializationTest method createRecordTuple.

private static Tuple<TypedRecord, CopiedRecord> createRecordTuple() {
    final RecordMetadata recordMetadata = new RecordMetadata();
    final DeploymentIntent intent = DeploymentIntent.CREATE;
    final int protocolVersion = 1;
    final ValueType valueType = ValueType.DEPLOYMENT;
    final RecordType recordType = RecordType.COMMAND;
    final String rejectionReason = "fails";
    final RejectionType rejectionType = RejectionType.INVALID_ARGUMENT;
    final int requestId = 23;
    final int requestStreamId = 1;
    recordMetadata.intent(intent).protocolVersion(protocolVersion).valueType(valueType).recordType(recordType).rejectionReason(rejectionReason).rejectionType(rejectionType).requestId(requestId).requestStreamId(requestStreamId);
    final String resourceName = "resource";
    final DirectBuffer resource = wrapString("contents");
    final String bpmnProcessId = "testProcess";
    final long processDefinitionKey = 123;
    final int processVersion = 12;
    final DeploymentRecord record = new DeploymentRecord();
    record.resources().add().setResourceName(wrapString(resourceName)).setResource(resource);
    record.processesMetadata().add().setBpmnProcessId(wrapString(bpmnProcessId)).setKey(processDefinitionKey).setResourceName(wrapString(resourceName)).setVersion(processVersion).setChecksum(wrapString("checksum"));
    final long key = 1234;
    final long position = 4321;
    final long sourcePosition = 231;
    final long timestamp = 2191L;
    final LoggedEvent loggedEvent = mock(LoggedEvent.class);
    when(loggedEvent.getPosition()).thenReturn(position);
    when(loggedEvent.getKey()).thenReturn(key);
    when(loggedEvent.getSourceEventPosition()).thenReturn(sourcePosition);
    when(loggedEvent.getTimestamp()).thenReturn(timestamp);
    final TypedEventImpl typedEvent = new TypedEventImpl(0);
    typedEvent.wrap(loggedEvent, recordMetadata, record);
    final CopiedRecord copiedRecord = new CopiedRecord<>(record, recordMetadata, key, 0, position, sourcePosition, timestamp);
    return new Tuple<>(typedEvent, copiedRecord);
}
Also used : RejectionType(io.camunda.zeebe.protocol.record.RejectionType) LoggedEvent(io.camunda.zeebe.logstreams.log.LoggedEvent) ValueType(io.camunda.zeebe.protocol.record.ValueType) BufferUtil.wrapString(io.camunda.zeebe.util.buffer.BufferUtil.wrapString) DeploymentIntent(io.camunda.zeebe.protocol.record.intent.DeploymentIntent) RecordMetadata(io.camunda.zeebe.protocol.impl.record.RecordMetadata) DirectBuffer(org.agrona.DirectBuffer) RecordType(io.camunda.zeebe.protocol.record.RecordType) DeploymentRecord(io.camunda.zeebe.protocol.impl.record.value.deployment.DeploymentRecord) CopiedRecord(io.camunda.zeebe.protocol.impl.record.CopiedRecord) Tuple(io.camunda.zeebe.util.collection.Tuple)

Example 3 with LoggedEvent

use of io.camunda.zeebe.logstreams.log.LoggedEvent in project zeebe by camunda.

the class TypedStreamProcessorTest method shouldSkipFailingEvent.

@Test
public void shouldSkipFailingEvent() {
    // given
    streams.startStreamProcessor(STREAM_NAME, DefaultZeebeDbFactory.defaultFactory(), (processingContext) -> TypedRecordProcessors.processors(keyGenerator, processingContext.getWriters()).onCommand(ValueType.DEPLOYMENT, DeploymentIntent.CREATE, new ErrorProneProcessor()));
    final AtomicLong requestId = new AtomicLong(0);
    final AtomicInteger requestStreamId = new AtomicInteger(0);
    when(mockCommandResponseWriter.tryWriteResponse(anyInt(), anyLong())).then((invocationOnMock -> {
        final int streamIdArg = invocationOnMock.getArgument(0);
        final long requestIdArg = invocationOnMock.getArgument(1);
        requestId.set(requestIdArg);
        requestStreamId.set(streamIdArg);
        return true;
    }));
    final long failingKey = keyGenerator.nextKey();
    streams.newRecord(STREAM_NAME).event(deployment("foo")).recordType(RecordType.COMMAND).intent(DeploymentIntent.CREATE).requestId(255L).requestStreamId(99).key(failingKey).write();
    final long secondEventPosition = streams.newRecord(STREAM_NAME).event(deployment("foo2")).recordType(RecordType.COMMAND).intent(DeploymentIntent.CREATE).key(keyGenerator.nextKey()).write();
    // when
    final LoggedEvent writtenEvent = TestUtil.doRepeatedly(() -> streams.events(STREAM_NAME).filter(e -> Records.isEvent(e, ValueType.DEPLOYMENT, DeploymentIntent.CREATED)).findFirst()).until(o -> o.isPresent()).get();
    // then
    assertThat(writtenEvent.getKey()).isEqualTo(1);
    assertThat(writtenEvent.getSourceEventPosition()).isEqualTo(secondEventPosition);
    // error response
    verify(mockCommandResponseWriter).tryWriteResponse(anyInt(), anyLong());
    assertThat(requestId.get()).isEqualTo(255L);
    assertThat(requestStreamId.get()).isEqualTo(99);
    final Record<DeploymentRecord> deploymentRejection = new RecordStream(streams.events(STREAM_NAME)).onlyDeploymentRecords().onlyRejections().withIntent(DeploymentIntent.CREATE).getFirst();
    assertThat(deploymentRejection.getKey()).isEqualTo(failingKey);
    assertThat(deploymentRejection.getRejectionType()).isEqualTo(RejectionType.PROCESSING_ERROR);
}
Also used : ArgumentMatchers.anyLong(org.mockito.ArgumentMatchers.anyLong) RecordType(io.camunda.zeebe.protocol.record.RecordType) AutoCloseableRule(io.camunda.zeebe.test.util.AutoCloseableRule) BufferUtil.wrapString(io.camunda.zeebe.util.buffer.BufferUtil.wrapString) DefaultZeebeDbFactory(io.camunda.zeebe.engine.state.DefaultZeebeDbFactory) DeploymentIntent(io.camunda.zeebe.protocol.record.intent.DeploymentIntent) Assertions.assertThat(org.assertj.core.api.Assertions.assertThat) ValueType(io.camunda.zeebe.protocol.record.ValueType) CommandResponseWriter(io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter) TypedResponseWriter(io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter) Record(io.camunda.zeebe.protocol.record.Record) MockitoAnnotations(org.mockito.MockitoAnnotations) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) SynchronousLogStream(io.camunda.zeebe.logstreams.util.SynchronousLogStream) TestUtil(io.camunda.zeebe.test.util.TestUtil) ActorSchedulerRule(io.camunda.zeebe.util.sched.testing.ActorSchedulerRule) Records(io.camunda.zeebe.engine.util.Records) TypedStreamWriter(io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriter) ArgumentMatchers.anyInt(org.mockito.ArgumentMatchers.anyInt) LoggedEvent(io.camunda.zeebe.logstreams.log.LoggedEvent) Before(org.junit.Before) TestStreams(io.camunda.zeebe.engine.util.TestStreams) KeyGenerator(io.camunda.zeebe.engine.state.KeyGenerator) Test(org.junit.Test) Mockito.when(org.mockito.Mockito.when) Mockito.verify(org.mockito.Mockito.verify) RuleChain(org.junit.rules.RuleChain) AtomicLong(java.util.concurrent.atomic.AtomicLong) Rule(org.junit.Rule) RejectionType(io.camunda.zeebe.protocol.record.RejectionType) DeploymentRecord(io.camunda.zeebe.protocol.impl.record.value.deployment.DeploymentRecord) RecordStream(io.camunda.zeebe.engine.util.RecordStream) TemporaryFolder(org.junit.rules.TemporaryFolder) AtomicLong(java.util.concurrent.atomic.AtomicLong) RecordStream(io.camunda.zeebe.engine.util.RecordStream) LoggedEvent(io.camunda.zeebe.logstreams.log.LoggedEvent) DeploymentRecord(io.camunda.zeebe.protocol.impl.record.value.deployment.DeploymentRecord) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) Test(org.junit.Test)

Example 4 with LoggedEvent

use of io.camunda.zeebe.logstreams.log.LoggedEvent in project zeebe by camunda.

the class TypedStreamProcessorTest method shouldWriteSourceEventAndProducerOnBatch.

@Test
public void shouldWriteSourceEventAndProducerOnBatch() {
    // given
    streams.startStreamProcessor(STREAM_NAME, DefaultZeebeDbFactory.defaultFactory(), (processingContext) -> TypedRecordProcessors.processors(keyGenerator, processingContext.getWriters()).onCommand(ValueType.DEPLOYMENT, DeploymentIntent.CREATE, new BatchProcessor()));
    final long firstEventPosition = streams.newRecord(STREAM_NAME).event(deployment("foo")).recordType(RecordType.COMMAND).intent(DeploymentIntent.CREATE).write();
    // when
    final LoggedEvent writtenEvent = TestUtil.doRepeatedly(() -> streams.events(STREAM_NAME).filter(e -> Records.isEvent(e, ValueType.DEPLOYMENT, DeploymentIntent.CREATED)).findFirst()).until(o -> o.isPresent()).get();
    // then
    assertThat(writtenEvent.getSourceEventPosition()).isEqualTo(firstEventPosition);
}
Also used : ArgumentMatchers.anyLong(org.mockito.ArgumentMatchers.anyLong) RecordType(io.camunda.zeebe.protocol.record.RecordType) AutoCloseableRule(io.camunda.zeebe.test.util.AutoCloseableRule) BufferUtil.wrapString(io.camunda.zeebe.util.buffer.BufferUtil.wrapString) DefaultZeebeDbFactory(io.camunda.zeebe.engine.state.DefaultZeebeDbFactory) DeploymentIntent(io.camunda.zeebe.protocol.record.intent.DeploymentIntent) Assertions.assertThat(org.assertj.core.api.Assertions.assertThat) ValueType(io.camunda.zeebe.protocol.record.ValueType) CommandResponseWriter(io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter) TypedResponseWriter(io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter) Record(io.camunda.zeebe.protocol.record.Record) MockitoAnnotations(org.mockito.MockitoAnnotations) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) SynchronousLogStream(io.camunda.zeebe.logstreams.util.SynchronousLogStream) TestUtil(io.camunda.zeebe.test.util.TestUtil) ActorSchedulerRule(io.camunda.zeebe.util.sched.testing.ActorSchedulerRule) Records(io.camunda.zeebe.engine.util.Records) TypedStreamWriter(io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriter) ArgumentMatchers.anyInt(org.mockito.ArgumentMatchers.anyInt) LoggedEvent(io.camunda.zeebe.logstreams.log.LoggedEvent) Before(org.junit.Before) TestStreams(io.camunda.zeebe.engine.util.TestStreams) KeyGenerator(io.camunda.zeebe.engine.state.KeyGenerator) Test(org.junit.Test) Mockito.when(org.mockito.Mockito.when) Mockito.verify(org.mockito.Mockito.verify) RuleChain(org.junit.rules.RuleChain) AtomicLong(java.util.concurrent.atomic.AtomicLong) Rule(org.junit.Rule) RejectionType(io.camunda.zeebe.protocol.record.RejectionType) DeploymentRecord(io.camunda.zeebe.protocol.impl.record.value.deployment.DeploymentRecord) RecordStream(io.camunda.zeebe.engine.util.RecordStream) TemporaryFolder(org.junit.rules.TemporaryFolder) LoggedEvent(io.camunda.zeebe.logstreams.log.LoggedEvent) Test(org.junit.Test)

Example 5 with LoggedEvent

use of io.camunda.zeebe.logstreams.log.LoggedEvent in project zeebe by camunda.

the class BlacklistInstanceTest method shouldBlacklist.

@Test
public void shouldBlacklist() {
    // given
    final RecordMetadata metadata = new RecordMetadata();
    metadata.intent(recordIntent);
    metadata.valueType(recordValueType);
    final TypedEventImpl typedEvent = new TypedEventImpl(1);
    final LoggedEvent loggedEvent = mock(LoggedEvent.class);
    when(loggedEvent.getPosition()).thenReturn(1024L);
    typedEvent.wrap(loggedEvent, metadata, new Value());
    // when
    final MutableZeebeState zeebeState = ZEEBE_STATE_RULE.getZeebeState();
    zeebeState.getBlackListState().tryToBlacklist(typedEvent, (processInstanceKey) -> {
    });
    // then
    metadata.intent(ProcessInstanceIntent.ELEMENT_ACTIVATING);
    metadata.valueType(ValueType.PROCESS_INSTANCE);
    typedEvent.wrap(null, metadata, new Value());
    assertThat(zeebeState.getBlackListState().isOnBlacklist(typedEvent)).isEqualTo(expectedToBlacklist);
}
Also used : RecordMetadata(io.camunda.zeebe.protocol.impl.record.RecordMetadata) MutableZeebeState(io.camunda.zeebe.engine.state.mutable.MutableZeebeState) LoggedEvent(io.camunda.zeebe.logstreams.log.LoggedEvent) UnifiedRecordValue(io.camunda.zeebe.protocol.impl.record.UnifiedRecordValue) Test(org.junit.Test)

Aggregations

LoggedEvent (io.camunda.zeebe.logstreams.log.LoggedEvent)53 Test (org.junit.Test)24 RecordMetadata (io.camunda.zeebe.protocol.impl.record.RecordMetadata)15 DeploymentRecord (io.camunda.zeebe.protocol.impl.record.value.deployment.DeploymentRecord)12 DeploymentIntent (io.camunda.zeebe.protocol.record.intent.DeploymentIntent)12 Assertions.assertThat (org.assertj.core.api.Assertions.assertThat)12 ValueType (io.camunda.zeebe.protocol.record.ValueType)10 TypedEventImpl (io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl)9 CommandResponseWriter (io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter)9 DefaultZeebeDbFactory (io.camunda.zeebe.engine.state.DefaultZeebeDbFactory)9 LogStreamReader (io.camunda.zeebe.logstreams.log.LogStreamReader)9 Record (io.camunda.zeebe.protocol.record.Record)9 TestUtil (io.camunda.zeebe.test.util.TestUtil)9 SynchronousLogStream (io.camunda.zeebe.logstreams.util.SynchronousLogStream)8 RecordType (io.camunda.zeebe.protocol.record.RecordType)8 RejectionType (io.camunda.zeebe.protocol.record.RejectionType)8 BufferUtil.wrapString (io.camunda.zeebe.util.buffer.BufferUtil.wrapString)8 MutableZeebeState (io.camunda.zeebe.engine.state.mutable.MutableZeebeState)6 UnifiedRecordValue (io.camunda.zeebe.protocol.impl.record.UnifiedRecordValue)6 TypedResponseWriter (io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter)5