Search in sources :

Example 81 with DirectChannel

use of org.springframework.integration.channel.DirectChannel in project spring-cloud-stream by spring-cloud.

the class PartitionCapableBinderTests method testOneRequiredGroup.

@Test
public void testOneRequiredGroup() throws Exception {
    B binder = getBinder();
    PP producerProperties = createProducerProperties();
    DirectChannel output = createBindableChannel("output", createProducerBindingProperties(producerProperties));
    String testDestination = "testDestination" + UUID.randomUUID().toString().replace("-", "");
    producerProperties.setRequiredGroups("test1");
    Binding<MessageChannel> producerBinding = binder.bindProducer(testDestination, output, producerProperties);
    String testPayload = "foo-" + UUID.randomUUID().toString();
    output.send(MessageBuilder.withPayload(testPayload).setHeader(MessageHeaders.CONTENT_TYPE, MimeTypeUtils.TEXT_PLAIN).build());
    QueueChannel inbound1 = new QueueChannel();
    Binding<MessageChannel> consumerBinding = binder.bindConsumer(testDestination, "test1", inbound1, createConsumerProperties());
    Message<?> receivedMessage1 = receive(inbound1);
    assertThat(receivedMessage1).isNotNull();
    assertThat(new String((byte[]) receivedMessage1.getPayload())).isEqualTo(testPayload);
    producerBinding.unbind();
    consumerBinding.unbind();
}
Also used : MessageChannel(org.springframework.messaging.MessageChannel) QueueChannel(org.springframework.integration.channel.QueueChannel) DirectChannel(org.springframework.integration.channel.DirectChannel) Test(org.junit.Test)

Example 82 with DirectChannel

use of org.springframework.integration.channel.DirectChannel in project spring-cloud-stream by spring-cloud.

the class PartitionCapableBinderTests method testPartitionedModuleSpEL.

@Test
public void testPartitionedModuleSpEL() throws Exception {
    B binder = getBinder();
    CP consumerProperties = createConsumerProperties();
    consumerProperties.setConcurrency(2);
    consumerProperties.setInstanceIndex(0);
    consumerProperties.setInstanceCount(3);
    consumerProperties.setPartitioned(true);
    QueueChannel input0 = new QueueChannel();
    input0.setBeanName("test.input0S");
    Binding<MessageChannel> input0Binding = binder.bindConsumer(String.format("part%s0", getDestinationNameDelimiter()), "testPartitionedModuleSpEL", input0, consumerProperties);
    consumerProperties.setInstanceIndex(1);
    QueueChannel input1 = new QueueChannel();
    input1.setBeanName("test.input1S");
    Binding<MessageChannel> input1Binding = binder.bindConsumer(String.format("part%s0", getDestinationNameDelimiter()), "testPartitionedModuleSpEL", input1, consumerProperties);
    consumerProperties.setInstanceIndex(2);
    QueueChannel input2 = new QueueChannel();
    input2.setBeanName("test.input2S");
    Binding<MessageChannel> input2Binding = binder.bindConsumer(String.format("part%s0", getDestinationNameDelimiter()), "testPartitionedModuleSpEL", input2, consumerProperties);
    PP producerProperties = createProducerProperties();
    producerProperties.setPartitionKeyExpression(spelExpressionParser.parseExpression("payload"));
    producerProperties.setPartitionSelectorExpression(spelExpressionParser.parseExpression("hashCode()"));
    producerProperties.setPartitionCount(3);
    DirectChannel output = createBindableChannel("output", createProducerBindingProperties(producerProperties));
    output.setBeanName("test.output");
    Binding<MessageChannel> outputBinding = binder.bindProducer(String.format("part%s0", getDestinationNameDelimiter()), output, producerProperties);
    try {
        Object endpoint = extractEndpoint(outputBinding);
        checkRkExpressionForPartitionedModuleSpEL(endpoint);
    } catch (UnsupportedOperationException ignored) {
    }
    Message<String> message2 = MessageBuilder.withPayload("2").setHeader(IntegrationMessageHeaderAccessor.CORRELATION_ID, "foo").setHeader(MessageHeaders.CONTENT_TYPE, MimeTypeUtils.TEXT_PLAIN).setHeader(IntegrationMessageHeaderAccessor.SEQUENCE_NUMBER, 42).setHeader(IntegrationMessageHeaderAccessor.SEQUENCE_SIZE, 43).build();
    output.send(message2);
    output.send(MessageBuilder.withPayload("1").setHeader(MessageHeaders.CONTENT_TYPE, MimeTypeUtils.TEXT_PLAIN).build());
    output.send(MessageBuilder.withPayload("0").setHeader(MessageHeaders.CONTENT_TYPE, MimeTypeUtils.TEXT_PLAIN).build());
    Message<?> receive0 = receive(input0);
    assertThat(receive0).isNotNull();
    Message<?> receive1 = receive(input1);
    assertThat(receive1).isNotNull();
    Message<?> receive2 = receive(input2);
    assertThat(receive2).isNotNull();
    Condition<Message<?>> correlationHeadersForPayload2 = new Condition<Message<?>>() {

        @Override
        public boolean matches(Message<?> value) {
            IntegrationMessageHeaderAccessor accessor = new IntegrationMessageHeaderAccessor(value);
            return "foo".equals(accessor.getCorrelationId()) && 42 == accessor.getSequenceNumber() && 43 == accessor.getSequenceSize();
        }
    };
    if (usesExplicitRouting()) {
        assertThat(receive0.getPayload()).isEqualTo("0".getBytes());
        assertThat(receive1.getPayload()).isEqualTo("1".getBytes());
        assertThat(receive2.getPayload()).isEqualTo("2".getBytes());
        assertThat(receive2).has(correlationHeadersForPayload2);
    } else {
        List<Message<?>> receivedMessages = Arrays.asList(receive0, receive1, receive2);
        assertThat(receivedMessages).extracting("payload").containsExactlyInAnyOrder("0".getBytes(), "1".getBytes(), "2".getBytes());
        Condition<Message<?>> payloadIs2 = new Condition<Message<?>>() {

            @Override
            public boolean matches(Message<?> value) {
                return value.getPayload().equals("2".getBytes());
            }
        };
        assertThat(receivedMessages).filteredOn(payloadIs2).areExactly(1, correlationHeadersForPayload2);
    }
    input0Binding.unbind();
    input1Binding.unbind();
    input2Binding.unbind();
    outputBinding.unbind();
}
Also used : Condition(org.assertj.core.api.Condition) QueueChannel(org.springframework.integration.channel.QueueChannel) Message(org.springframework.messaging.Message) DirectChannel(org.springframework.integration.channel.DirectChannel) IntegrationMessageHeaderAccessor(org.springframework.integration.IntegrationMessageHeaderAccessor) MessageChannel(org.springframework.messaging.MessageChannel) Test(org.junit.Test)

Example 83 with DirectChannel

use of org.springframework.integration.channel.DirectChannel in project spring-cloud-stream by spring-cloud.

the class PartitionCapableBinderTests method testTwoRequiredGroups.

@Test
public void testTwoRequiredGroups() throws Exception {
    B binder = getBinder();
    PP producerProperties = createProducerProperties();
    DirectChannel output = createBindableChannel("output", createProducerBindingProperties(producerProperties));
    String testDestination = "testDestination" + UUID.randomUUID().toString().replace("-", "");
    producerProperties.setRequiredGroups("test1", "test2");
    Binding<MessageChannel> producerBinding = binder.bindProducer(testDestination, output, producerProperties);
    String testPayload = "foo-" + UUID.randomUUID().toString();
    output.send(MessageBuilder.withPayload(testPayload).setHeader(MessageHeaders.CONTENT_TYPE, MimeTypeUtils.TEXT_PLAIN).build());
    QueueChannel inbound1 = new QueueChannel();
    Binding<MessageChannel> consumerBinding1 = binder.bindConsumer(testDestination, "test1", inbound1, createConsumerProperties());
    QueueChannel inbound2 = new QueueChannel();
    Binding<MessageChannel> consumerBinding2 = binder.bindConsumer(testDestination, "test2", inbound2, createConsumerProperties());
    Message<?> receivedMessage1 = receive(inbound1);
    assertThat(receivedMessage1).isNotNull();
    assertThat(new String((byte[]) receivedMessage1.getPayload())).isEqualTo(testPayload);
    Message<?> receivedMessage2 = receive(inbound2);
    assertThat(receivedMessage2).isNotNull();
    assertThat(new String((byte[]) receivedMessage2.getPayload())).isEqualTo(testPayload);
    consumerBinding1.unbind();
    consumerBinding2.unbind();
    producerBinding.unbind();
}
Also used : MessageChannel(org.springframework.messaging.MessageChannel) QueueChannel(org.springframework.integration.channel.QueueChannel) DirectChannel(org.springframework.integration.channel.DirectChannel) Test(org.junit.Test)

Example 84 with DirectChannel

use of org.springframework.integration.channel.DirectChannel in project spring-cloud-stream by spring-cloud.

the class BinderAwareChannelResolverTests method resolveChannel.

@Test
public void resolveChannel() {
    Map<String, Bindable> bindables = context.getBeansOfType(Bindable.class);
    assertThat(bindables).hasSize(1);
    for (Bindable bindable : bindables.values()) {
        // producer
        assertEquals(0, bindable.getInputs().size());
        // consumer
        assertEquals(0, bindable.getOutputs().size());
    }
    MessageChannel registered = resolver.resolveDestination("foo");
    assertEquals(2, ((AbstractMessageChannel) registered).getChannelInterceptors().size());
    assertTrue(((AbstractMessageChannel) registered).getChannelInterceptors().get(1) instanceof ImmutableMessageChannelInterceptor);
    bindables = context.getBeansOfType(Bindable.class);
    assertThat(bindables).hasSize(1);
    for (Bindable bindable : bindables.values()) {
        // producer
        assertEquals(0, bindable.getInputs().size());
        // consumer
        assertEquals(1, bindable.getOutputs().size());
    }
    DirectChannel testChannel = new DirectChannel();
    testChannel.setComponentName("INPUT");
    final CountDownLatch latch = new CountDownLatch(1);
    final List<Message<?>> received = new ArrayList<>();
    testChannel.subscribe(new MessageHandler() {

        @Override
        public void handleMessage(Message<?> message) throws MessagingException {
            received.add(message);
            latch.countDown();
        }
    });
    this.binder.bindConsumer("foo", null, testChannel, new ConsumerProperties());
    assertThat(received).hasSize(0);
    registered.send(MessageBuilder.withPayload("hello").build());
    try {
        assertThat(latch.await(1, TimeUnit.SECONDS)).describedAs("Latch timed out");
    } catch (InterruptedException e) {
        Thread.currentThread().interrupt();
        fail("interrupted while awaiting latch");
    }
    assertThat(received).hasSize(1);
    assertThat(new String((byte[]) received.get(0).getPayload())).isEqualTo("hello");
    this.context.close();
    for (Bindable bindable : bindables.values()) {
        assertEquals(0, bindable.getInputs().size());
        // Must not be bound"
        assertEquals(0, bindable.getOutputs().size());
    }
}
Also used : AbstractMessageChannel(org.springframework.integration.channel.AbstractMessageChannel) Message(org.springframework.messaging.Message) MessageHandler(org.springframework.messaging.MessageHandler) DirectChannel(org.springframework.integration.channel.DirectChannel) MessagingException(org.springframework.messaging.MessagingException) ImmutableMessageChannelInterceptor(org.springframework.messaging.support.ImmutableMessageChannelInterceptor) Bindable(org.springframework.cloud.stream.binding.Bindable) DynamicDestinationsBindable(org.springframework.cloud.stream.binding.DynamicDestinationsBindable) ArrayList(java.util.ArrayList) CountDownLatch(java.util.concurrent.CountDownLatch) AbstractMessageChannel(org.springframework.integration.channel.AbstractMessageChannel) MessageChannel(org.springframework.messaging.MessageChannel) Test(org.junit.Test)

Example 85 with DirectChannel

use of org.springframework.integration.channel.DirectChannel in project spring-cloud-stream by spring-cloud.

the class ExtendedPropertiesBinderAwareChannelResolverTests method resolveChannel.

@Test
@Override
public void resolveChannel() {
    Map<String, Bindable> bindables = context.getBeansOfType(Bindable.class);
    assertThat(bindables).hasSize(1);
    for (Bindable bindable : bindables.values()) {
        // producer
        assertEquals(0, bindable.getInputs().size());
        // consumer
        assertEquals(0, bindable.getOutputs().size());
    }
    MessageChannel registered = resolver.resolveDestination("foo");
    bindables = context.getBeansOfType(Bindable.class);
    assertThat(bindables).hasSize(1);
    for (Bindable bindable : bindables.values()) {
        // producer
        assertEquals(0, bindable.getInputs().size());
        // consumer
        assertEquals(1, bindable.getOutputs().size());
    }
    DirectChannel testChannel = new DirectChannel();
    final CountDownLatch latch = new CountDownLatch(1);
    final List<Message<?>> received = new ArrayList<>();
    testChannel.subscribe(new MessageHandler() {

        @Override
        public void handleMessage(Message<?> message) throws MessagingException {
            received.add(message);
            latch.countDown();
        }
    });
    binder.bindConsumer("foo", null, testChannel, new ExtendedConsumerProperties<ConsumerProperties>(new ConsumerProperties()));
    assertThat(received).hasSize(0);
    registered.send(MessageBuilder.withPayload("hello").build());
    try {
        assertThat(latch.await(1, TimeUnit.SECONDS)).describedAs("latch timed out");
    } catch (InterruptedException e) {
        Thread.currentThread().interrupt();
        fail("interrupted while awaiting latch");
    }
    assertThat(received).hasSize(1);
    assertThat(new String((byte[]) received.get(0).getPayload())).isEqualTo("hello");
    context.close();
    for (Bindable bindable : bindables.values()) {
        assertEquals(0, bindable.getInputs().size());
        // Must not be bound"
        assertEquals(0, bindable.getOutputs().size());
    }
}
Also used : Message(org.springframework.messaging.Message) MessageHandler(org.springframework.messaging.MessageHandler) DirectChannel(org.springframework.integration.channel.DirectChannel) MessagingException(org.springframework.messaging.MessagingException) Bindable(org.springframework.cloud.stream.binding.Bindable) ArrayList(java.util.ArrayList) CountDownLatch(java.util.concurrent.CountDownLatch) MessageChannel(org.springframework.messaging.MessageChannel) Test(org.junit.Test)

Aggregations

DirectChannel (org.springframework.integration.channel.DirectChannel)215 Test (org.junit.Test)182 MessageChannel (org.springframework.messaging.MessageChannel)71 Message (org.springframework.messaging.Message)68 QueueChannel (org.springframework.integration.channel.QueueChannel)63 BeanFactory (org.springframework.beans.factory.BeanFactory)45 GenericMessage (org.springframework.messaging.support.GenericMessage)38 MessageHandler (org.springframework.messaging.MessageHandler)32 ClassPathXmlApplicationContext (org.springframework.context.support.ClassPathXmlApplicationContext)28 CountDownLatch (java.util.concurrent.CountDownLatch)27 ConfigurableApplicationContext (org.springframework.context.ConfigurableApplicationContext)26 BindingProperties (org.springframework.cloud.stream.config.BindingProperties)25 AbstractReplyProducingMessageHandler (org.springframework.integration.handler.AbstractReplyProducingMessageHandler)23 HashMap (java.util.HashMap)22 EventDrivenConsumer (org.springframework.integration.endpoint.EventDrivenConsumer)22 MessagingException (org.springframework.messaging.MessagingException)18 Properties (java.util.Properties)15 AtomicReference (java.util.concurrent.atomic.AtomicReference)15 SubscribableChannel (org.springframework.messaging.SubscribableChannel)15 Expression (org.springframework.expression.Expression)14