Search in sources :

Example 1 with OutgoingKafkaRecordMetadata

use of io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata in project sandbox by 5733d9e2be6485d52ffa08870cabdee0.

the class KafkaTopicInvokerTest method onEvent.

@Test
public void onEvent() {
    ArgumentCaptor<Message<String>> captor = ArgumentCaptor.forClass(Message.class);
    Emitter<String> emitter = mock(Emitter.class);
    String event = "{\"key\": \"value\"}";
    String topic = "myTestTopic";
    ProcessorDTO processor = createProcessor();
    KafkaTopicInvoker invoker = new KafkaTopicInvoker(emitter, processor, topic);
    invoker.onEvent(event);
    verify(emitter).send(captor.capture());
    Message<String> sent = captor.getValue();
    assertThat(sent.getPayload()).isEqualTo(event);
    Metadata metadata = sent.getMetadata();
    OutgoingKafkaRecordMetadata recordMetadata = metadata.get(OutgoingKafkaRecordMetadata.class).get();
    assertThat(recordMetadata.getTopic()).isEqualTo(topic);
}
Also used : Message(org.eclipse.microprofile.reactive.messaging.Message) ProcessorDTO(com.redhat.service.bridge.infra.models.dto.ProcessorDTO) OutgoingKafkaRecordMetadata(io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata) Metadata(org.eclipse.microprofile.reactive.messaging.Metadata) OutgoingKafkaRecordMetadata(io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata) Test(org.junit.jupiter.api.Test)

Example 2 with OutgoingKafkaRecordMetadata

use of io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata in project smallrye-reactive-messaging by smallrye.

the class KafkaRecordTest method testCreationOfKafkaRecordWithEverything.

@Test
public void testCreationOfKafkaRecordWithEverything() {
    Instant timestamp = Instant.now();
    KafkaRecord<String, String> message = KafkaRecord.of("topic", "foo", "bar", timestamp, 2);
    assertThat(message.getPayload()).isEqualTo("bar");
    assertThat(message.getKey()).isEqualTo("foo");
    assertThat(message.getTopic()).isEqualTo("topic");
    assertThat(message.getHeaders()).isEmpty();
    assertThat(message.getPartition()).isEqualTo(2);
    assertThat(message.getTimestamp()).isEqualTo(timestamp);
    OutgoingKafkaRecordMetadata<?> metadata = message.getMetadata(OutgoingKafkaRecordMetadata.class).orElseThrow(() -> new AssertionError("Metadata expected"));
    assertThat(metadata.getPartition()).isEqualTo(2);
    assertThat(metadata.getKey()).isEqualTo("foo");
    assertThat(metadata.getTopic()).isEqualTo("topic");
    assertThat(metadata.getTimestamp()).isEqualTo(timestamp);
    assertThat(metadata.getHeaders()).isEmpty();
    LegacyMetadataTestUtils.tempCompareLegacyAndApiMetadata(metadata, message);
}
Also used : Instant(java.time.Instant) OutgoingKafkaRecordMetadata(io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata) Test(org.junit.jupiter.api.Test)

Example 3 with OutgoingKafkaRecordMetadata

use of io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata in project smallrye-reactive-messaging by smallrye.

the class KafkaCloudEventHelper method createStructuredRecord.

@SuppressWarnings("rawtypes")
public static ProducerRecord<?, ?> createStructuredRecord(Message<?> message, String topic, OutgoingKafkaRecordMetadata<?> outgoingMetadata, IncomingKafkaRecordMetadata<?, ?> incomingMetadata, OutgoingCloudEventMetadata<?> ceMetadata, RuntimeKafkaSinkConfiguration configuration) {
    if (ceMetadata == null) {
        ceMetadata = OutgoingCloudEventMetadata.builder().build();
    }
    Integer partition = getPartition(outgoingMetadata, configuration);
    Object key = getKey(message, outgoingMetadata, ceMetadata, configuration);
    Long timestamp = getTimestamp(outgoingMetadata);
    List<Header> headers = getHeaders(outgoingMetadata, incomingMetadata, configuration);
    String source = getSource(ceMetadata, configuration);
    String type = getType(ceMetadata, configuration);
    Optional<String> subject = getSubject(ceMetadata, configuration);
    Optional<String> dataContentType = getDataContentType(ceMetadata, configuration);
    Optional<URI> schema = getDataSchema(ceMetadata, configuration);
    // if headers does not contain a "content-type" header add one
    Optional<Header> contentType = headers.stream().filter(h -> h.key().equalsIgnoreCase(KAFKA_HEADER_CONTENT_TYPE)).findFirst();
    if (!contentType.isPresent()) {
        headers.add(new RecordHeader(KAFKA_HEADER_CONTENT_TYPE, STRUCTURED_CONTENT_TYPE.getBytes()));
    }
    // We need to build the JSON Object representing the Cloud Event
    JsonObject json = new JsonObject();
    json.put(CE_ATTRIBUTE_SPEC_VERSION, ceMetadata.getSpecVersion()).put(CE_ATTRIBUTE_TYPE, type).put(CE_ATTRIBUTE_SOURCE, source).put(CE_ATTRIBUTE_ID, ceMetadata.getId());
    ZonedDateTime time = ceMetadata.getTimeStamp().orElse(null);
    if (time != null) {
        json.put(CE_ATTRIBUTE_TIME, time.toInstant());
    } else if (configuration.getCloudEventsInsertTimestamp()) {
        json.put(CE_ATTRIBUTE_TIME, Instant.now());
    }
    schema.ifPresent(s -> json.put(CE_ATTRIBUTE_DATA_SCHEMA, s));
    dataContentType.ifPresent(s -> json.put(CE_ATTRIBUTE_DATA_CONTENT_TYPE, s));
    subject.ifPresent(s -> json.put(CE_ATTRIBUTE_SUBJECT, s));
    // Extensions
    ceMetadata.getExtensions().forEach(json::put);
    // Encode the payload to json
    Object payload = message.getPayload();
    if (payload instanceof Record) {
        payload = ((Record) payload).value();
    }
    if (payload instanceof String) {
        json.put("data", payload);
    } else {
        json.put("data", JsonObject.mapFrom(payload));
    }
    return new ProducerRecord<>(topic, partition, timestamp, key, json.encode(), headers);
}
Also used : DateTimeFormatterBuilder(java.time.format.DateTimeFormatterBuilder) ChronoField(java.time.temporal.ChronoField) java.util(java.util) Record(io.smallrye.reactive.messaging.kafka.Record) ProducerRecord(org.apache.kafka.clients.producer.ProducerRecord) ZonedDateTime(java.time.ZonedDateTime) Headers(org.apache.kafka.common.header.Headers) RecordHeader(org.apache.kafka.common.header.internals.RecordHeader) CE_KAFKA_TOPIC(io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata.CE_KAFKA_TOPIC) IncomingKafkaRecordMetadata(io.smallrye.reactive.messaging.kafka.api.IncomingKafkaRecordMetadata) RuntimeKafkaSinkConfiguration(io.smallrye.reactive.messaging.kafka.impl.RuntimeKafkaSinkConfiguration) CloudEventMetadata(io.smallrye.reactive.messaging.ce.CloudEventMetadata) DefaultIncomingCloudEventMetadata(io.smallrye.reactive.messaging.ce.impl.DefaultIncomingCloudEventMetadata) BaseCloudEventMetadata(io.smallrye.reactive.messaging.ce.impl.BaseCloudEventMetadata) CE_KAFKA_KEY(io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata.CE_KAFKA_KEY) JsonObject(io.vertx.core.json.JsonObject) URI(java.net.URI) IncomingKafkaCloudEventMetadata(io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata) Instant(java.time.Instant) DefaultCloudEventMetadataBuilder(io.smallrye.reactive.messaging.ce.DefaultCloudEventMetadataBuilder) Collectors(java.util.stream.Collectors) StandardCharsets(java.nio.charset.StandardCharsets) Message(org.eclipse.microprofile.reactive.messaging.Message) OutgoingCloudEventMetadata(io.smallrye.reactive.messaging.ce.OutgoingCloudEventMetadata) OutgoingKafkaRecordMetadata(io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata) Buffer(io.vertx.mutiny.core.buffer.Buffer) Header(org.apache.kafka.common.header.Header) ConsumerRecord(org.apache.kafka.clients.consumer.ConsumerRecord) DateTimeFormatter(java.time.format.DateTimeFormatter) JsonObject(io.vertx.core.json.JsonObject) URI(java.net.URI) RecordHeader(org.apache.kafka.common.header.internals.RecordHeader) Header(org.apache.kafka.common.header.Header) ZonedDateTime(java.time.ZonedDateTime) ProducerRecord(org.apache.kafka.clients.producer.ProducerRecord) JsonObject(io.vertx.core.json.JsonObject) Record(io.smallrye.reactive.messaging.kafka.Record) ProducerRecord(org.apache.kafka.clients.producer.ProducerRecord) ConsumerRecord(org.apache.kafka.clients.consumer.ConsumerRecord) RecordHeader(org.apache.kafka.common.header.internals.RecordHeader)

Aggregations

OutgoingKafkaRecordMetadata (io.smallrye.reactive.messaging.kafka.api.OutgoingKafkaRecordMetadata)3 Instant (java.time.Instant)2 Message (org.eclipse.microprofile.reactive.messaging.Message)2 Test (org.junit.jupiter.api.Test)2 ProcessorDTO (com.redhat.service.bridge.infra.models.dto.ProcessorDTO)1 CloudEventMetadata (io.smallrye.reactive.messaging.ce.CloudEventMetadata)1 DefaultCloudEventMetadataBuilder (io.smallrye.reactive.messaging.ce.DefaultCloudEventMetadataBuilder)1 OutgoingCloudEventMetadata (io.smallrye.reactive.messaging.ce.OutgoingCloudEventMetadata)1 BaseCloudEventMetadata (io.smallrye.reactive.messaging.ce.impl.BaseCloudEventMetadata)1 DefaultIncomingCloudEventMetadata (io.smallrye.reactive.messaging.ce.impl.DefaultIncomingCloudEventMetadata)1 IncomingKafkaCloudEventMetadata (io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata)1 CE_KAFKA_KEY (io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata.CE_KAFKA_KEY)1 CE_KAFKA_TOPIC (io.smallrye.reactive.messaging.kafka.IncomingKafkaCloudEventMetadata.CE_KAFKA_TOPIC)1 Record (io.smallrye.reactive.messaging.kafka.Record)1 IncomingKafkaRecordMetadata (io.smallrye.reactive.messaging.kafka.api.IncomingKafkaRecordMetadata)1 RuntimeKafkaSinkConfiguration (io.smallrye.reactive.messaging.kafka.impl.RuntimeKafkaSinkConfiguration)1 JsonObject (io.vertx.core.json.JsonObject)1 Buffer (io.vertx.mutiny.core.buffer.Buffer)1 URI (java.net.URI)1 StandardCharsets (java.nio.charset.StandardCharsets)1