Package com.saasovation.common.port.adapter.messaging.rabbitmq

Examples of com.saasovation.common.port.adapter.messaging.rabbitmq.MessageProducer


        List<Notification> notifications =
            this.listUnpublishedNotifications(
                    publishedNotificationTracker.mostRecentPublishedNotificationId());

        MessageProducer messageProducer = this.messageProducer();

        try {
            for (Notification notification : notifications) {
                this.publish(notification, messageProducer);
            }

            this.publishedNotificationTrackerStore()
                .trackMostRecentPublishedNotification(
                    publishedNotificationTracker,
                    notifications);
        } finally {
            messageProducer.close();
        }
    }
View Full Code Here


                    ConnectionSettings.instance(),
                    this.exchangeName(),
                    true);

        // create a message producer used to forward events
        MessageProducer messageProducer = MessageProducer.instance(exchange);

        return messageProducer;
    }
View Full Code Here

            Exchange.fanOutInstance(
                    ConnectionSettings.instance(),
                    Exchanges.COLLABORATION_EXCHANGE_NAME,
                    true);

        MessageProducer messageProducer =
                MessageProducer.instance(exchange);

        return messageProducer;
    }
View Full Code Here

TOP

Related Classes of com.saasovation.common.port.adapter.messaging.rabbitmq.MessageProducer

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.