use of com.meltwater.rxrabbit.impl.DefaultChannelFactory in project rxrabbit by meltwater.
the class RxRabbitMultiNodeTest method setup.
@Before
public void setup() throws Exception {
dockerContainers.resetAll(false);
dockerContainers.rabbit(RABBIT_1).assertUp();
dockerContainers.rabbit(RABBIT_2).assertUp();
String rabbitTcpPort = dockerContainers.rabbit(RABBIT_1).tcpPort();
rabbitAdminPort = dockerContainers.rabbit(RABBIT_1).adminPort();
String rabbit2TcpPort = dockerContainers.rabbit(RABBIT_2).tcpPort();
log.infoWithParams("****** Rabbit brokers are up and running *****");
BrokerAddresses addresses = new BrokerAddresses("amqp://localhost:" + rabbitTcpPort + "," + "amqp://localhost:" + rabbit2TcpPort);
channelFactory = new DefaultChannelFactory(addresses, connectionSettings);
consumerFactory = new DefaultConsumerFactory(channelFactory, consumeSettings);
DefaultPublisherFactory publisherFactory = new DefaultPublisherFactory(channelFactory, publishSettings);
httpClient = new AsyncHttpClient();
messagesSeen.clear();
createQueues(channelFactory, inputQueue, new Exchange(inputExchange));
publisher = publisherFactory.createPublisher();
}
use of com.meltwater.rxrabbit.impl.DefaultChannelFactory in project rxrabbit by meltwater.
the class ExampleCode method publishAndConsume.
public int publishAndConsume(int numMessages, long maxWaitMillis, String brokerHost, int brokerPort, String queue, String exchange) throws IOException, InterruptedException {
// ---------- Set Up ----------
Logger logger = new Logger(ExampleCode.class);
final ConnectionSettings connectionSettings = new ConnectionSettings();
BrokerAddresses brokers = new BrokerAddresses(Lists.newArrayList(new BrokerAddresses.BrokerAddressBuilder().withHost(brokerHost).withPort(brokerPort).build()));
DefaultChannelFactory channelFactory = new DefaultChannelFactory(brokers, connectionSettings);
// Create queue, exchange and bind together
AdminChannel adminChannel = channelFactory.createAdminChannel();
adminChannel.exchangeDeclare(exchange, "topic", true, false, false, new HashMap<>());
adminChannel.queueDeclare(queue, true, false, false, new HashMap<>());
adminChannel.queueBind(queue, exchange, "#", new HashMap<>());
adminChannel.close();
// ---------- Publish messages ----------
final PublisherSettings publisherSettings = new PublisherSettings().withNumChannels(2).withPublisherConfirms(true).withRetryCount(3);
RabbitPublisher publisher = new DefaultPublisherFactory(channelFactory, publisherSettings).createPublisher();
Observable.range(0, numMessages).map(String::valueOf).flatMap((input) -> publisher.call(new Exchange(exchange), new RoutingKey("#"), new AMQP.BasicProperties(), new Payload(input.getBytes())).toObservable()).doOnError((e) -> logger.errorWithParams("Failed to publish message", e)).subscribe();
// ---------- Consume messages ----------
ConsumerSettings consumerSettings = new ConsumerSettings().withRetryCount(ConsumerSettings.RETRY_FOREVER).withNumChannels(1).withPreFetchCount(1024);
Observable<Message> consumer = new DefaultConsumerFactory(channelFactory, consumerSettings).createConsumer(queue);
final AtomicInteger consumedMessages = new AtomicInteger(0);
// save the Subscription so you can stop consuming later
Subscription consumeSubscription = consumer.doOnNext(message -> consumedMessages.incrementAndGet()).doOnNext(message -> message.acknowledger.ack()).subscribe();
try {
long startTime = System.currentTimeMillis();
while (consumedMessages.get() < numMessages) {
Thread.sleep(10);
if ((System.currentTimeMillis() - startTime) > maxWaitMillis) {
throw new RuntimeException("Did not receive all '" + numMessages + "' messages within '" + maxWaitMillis + "' millis.");
}
}
} finally {
// unsubscribe (closes consume channel, and the consume connection if there are no other consumers)
consumeSubscription.unsubscribe();
// closes publish channel, and the publish connection of there are no other publishers
publisher.close();
}
return consumedMessages.get();
}
use of com.meltwater.rxrabbit.impl.DefaultChannelFactory in project rxrabbit by meltwater.
the class RxRabbitTests method setup.
@Before
public void setup() throws Exception {
dockerContainers.rabbit().assertUp();
rabbitTcpPort = dockerContainers.rabbit().tcpPort();
rabbitAdminPort = dockerContainers.rabbit().adminPort();
log.infoWithParams("****** Rabbit broker is up and running *****");
BrokerAddresses addresses = new BrokerAddresses("amqp://localhost:" + rabbitTcpPort);
channelFactory = new DefaultChannelFactory(addresses, connectionSettings);
consumerFactory = new DefaultConsumerFactory(channelFactory, consumeSettings);
publisherFactory = new DefaultPublisherFactory(channelFactory, publishSettings);
httpClient = new AsyncHttpClient();
messagesSeen.clear();
createQueues(channelFactory, inputQueue, new Exchange(inputExchange));
publisher = publisherFactory.createPublisher();
RxJavaHooks.setOnIOScheduler(null);
}
use of com.meltwater.rxrabbit.impl.DefaultChannelFactory in project rxrabbit by meltwater.
the class LoadGenerator method publishTestMessages.
public static void publishTestMessages(BrokerAddresses addresses, String outputExchange, long nrToPublish) throws IOException {
ConnectionSettings connectionSettings = new ConnectionSettings();
connectionSettings.withHeartbeatSecs(5);
connectionSettings.withShutdownTimeoutMillis(10_000);
PublisherSettings publisherSettings = new PublisherSettings();
publisherSettings.withPublisherConfirms(true);
publisherSettings.withBackoffAlgorithm(new FibonacciBackoffAlgorithm());
publisherSettings.withRetryCount(10);
ChannelFactory channelFactory = new DefaultChannelFactory(addresses, connectionSettings);
PublisherFactory publisherFactory = new DefaultPublisherFactory(channelFactory, publisherSettings);
final RabbitPublisher publish = publisherFactory.createPublisher();
List<Long> ids = new ArrayList<>();
for (long i = 1; i <= nrToPublish; i++) {
ids.add(i);
}
log.infoWithParams("Publishing messages to exchange.", "numToPublish", nrToPublish, "exchange", outputExchange);
from(ids).flatMap(id -> {
AMQP.BasicProperties.Builder builder = new AMQP.BasicProperties().builder();
builder.messageId(String.valueOf(id));
builder.deliveryMode(DeliveryMode.persistent.code);
builder.appId("load-generator");
String msgPayload = "Message nr " + id;
return publish.call(new Exchange(outputExchange), new RoutingKey("routing.key"), builder.build(), new Payload(msgPayload.getBytes(Charsets.UTF_8))).toObservable();
}).doOnError(throwable -> log.errorWithParams("Unexpected error when publishing.", throwable)).timeout(30, TimeUnit.SECONDS).toBlocking().last();
log.infoWithParams("All messages sent to exchange.", "numSent", nrToPublish, "exchange", outputExchange);
publish.close();
}
use of com.meltwater.rxrabbit.impl.DefaultChannelFactory in project rxrabbit by meltwater.
the class ExampleAppsTest method setup.
@Before
public void setup() throws Exception {
killAndRestartRabbitDocker();
prop = new Properties();
prop.load(ExampleAppsTest.class.getResourceAsStream("/test.properties"));
prop.putAll(System.getProperties());
addresses = new BrokerAddresses(prop.getProperty("rabbit.broker.uris"));
channelFactory = new DefaultChannelFactory(addresses, new ConnectionSettings());
RabbitTestUtils.createQueues(channelFactory, prop.getProperty("in.queue"), new Exchange(prop.getProperty("in.exchange")));
RabbitTestUtils.createQueues(channelFactory, prop.getProperty("out.queue"), new Exchange(prop.getProperty("out.exchange")));
}
Aggregations