Example usage for com.rabbitmq.client ConnectionFactory ConnectionFactory

List of usage examples for com.rabbitmq.client ConnectionFactory ConnectionFactory

Introduction

In this page you can find the example usage for com.rabbitmq.client ConnectionFactory ConnectionFactory.

Prototype

ConnectionFactory

Source Link

Usage

From source file:dk.getcreditscore.messaging.Send.java

public static void sendMessage(String message) throws IOException {
    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost("datdb.cphbusiness.dk");
    factory.setUsername("student");
    factory.setPassword("cph");
    Connection connection = factory.newConnection();
    Channel channel = connection.createChannel();

    channel.queueDeclare(TASK_QUEUE_NAME, true, false, false, null);

    channel.basicPublish("", TASK_QUEUE_NAME, MessageProperties.PERSISTENT_TEXT_PLAIN, message.getBytes());

    channel.close();// w  w w .  j  a  va  2s . c  om
    connection.close();
}

From source file:dk.normalizer.messaging.Receive.java

public static HashMap<String, Object> setUpReceiver() throws java.io.IOException {
    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost("datdb.cphbusiness.dk");
    factory.setUsername("student");
    factory.setPassword("cph");
    connection = factory.newConnection();
    channel = connection.createChannel();

    channel.queueDeclare(TASK_QUEUE_NAME, true, false, false, null);
    System.out.println(" [*] Waiting for messages. To exit press CTRL+C");

    channel.basicQos(1);/*from  w  ww . j a  v a  2s. c o  m*/

    QueueingConsumer consumer = new QueueingConsumer(channel);
    channel.basicConsume(TASK_QUEUE_NAME, false, consumer);

    HashMap<String, Object> returnObjects = new HashMap<>();

    returnObjects.put("channel", channel);
    returnObjects.put("consumer", consumer);

    return returnObjects;
}

From source file:dreamteamjson.DreamTeamJSON.java

/**
 * @param args the command line arguments
 * @throws java.io.IOException//w  w  w.j a  v  a  2s. c om
 */
public static void main(String[] args) throws IOException {

    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost("datdb.cphbusiness.dk");
    factory.setUsername("Dreamteam");
    factory.setPassword("bastian");
    Connection connection = factory.newConnection();
    Channel listeningChannel = connection.createChannel();
    Channel sendingChannel = connection.createChannel();

    listeningChannel.queueDeclare(LISTENING_QUEUE_NAME, false, false, false, null);
    System.out.println(" [*] Waiting for messages. To exit press CTRL+C");

    Consumer consumer = new DefaultConsumer(listeningChannel) {
        @Override
        public void handleDelivery(String consumerTag, Envelope envelope, AMQP.BasicProperties properties,
                byte[] body) throws IOException {
            message = new String(body, "UTF-8");
            System.out.println(" [x] Received '" + message + "'");

            Message m = gson.fromJson(message, Message.class);
            System.out.println(m.toString());

            double interestRate = 14;

            if (m.creditScore > 600) {
                interestRate -= 4.5;
            } else if (m.creditScore < 601 && m.creditScore > 500) {
                interestRate -= 2.7;
            } else if (m.creditScore < 501 && m.creditScore > 400) {
                interestRate -= 0.9;
            }

            int durationCut = m.loanDuration / 360;

            interestRate -= (durationCut * 0.18);

            double amountCut = m.loanAmount / 100000;

            interestRate -= (amountCut * 0.18);

            // Insert bank logic

            String loanResponse = "{\"interestRate\":" + interestRate + ",\"ssn\":" + m.ssn + "}";

            sendingChannel.queueDeclare(SENDING_QUEUE_NAME, false, false, false, null);
            sendingChannel.basicPublish("", SENDING_QUEUE_NAME, null, loanResponse.getBytes());
        }
    };
    listeningChannel.basicConsume(LISTENING_QUEUE_NAME, true, consumer);

}

From source file:dreamteamxmltranslator.Translator.java

public static void main(String[] args) throws IOException {

    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost("datdb.cphbusiness.dk");
    factory.setUsername("Dreamteam");
    factory.setPassword("bastian");
    Connection connection = factory.newConnection();
    Channel channel = connection.createChannel();

    channel.queueDeclare(LISTENING_QUEUE_NAME, false, false, false, null);
    channel.queueBind(LISTENING_QUEUE_NAME, EXCHANGE_NAME, "DreamTeamBankXML");

    System.out.println(" [*] Waiting for messages. To exit press CTRL+C");

    Consumer consumer = new DefaultConsumer(channel) {
        @Override/*from   w w w  .j av  a 2 s .  c  om*/
        public void handleDelivery(String consumerTag, Envelope envelope, AMQP.BasicProperties properties,
                byte[] body) throws IOException {
            try {
                message = new String(body, "UTF-8");
                System.out.println(" [x] Received '" + message + "'");

                String[] arr = message.split(",");
                tester(arr);
            } catch (IOException_Exception ex) {
                Logger.getLogger(Translator.class.getName()).log(Level.SEVERE, null, ex);
            }

        }
    };
    channel.basicConsume(LISTENING_QUEUE_NAME, true, consumer);

}

From source file:dummyloanbroker.DummyLoanBroker.java

public static void main(String[] args) throws IOException {
    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost("datdb.cphbusiness.dk");
    factory.setUsername("student");
    factory.setPassword("cph");
    com.rabbitmq.client.Connection connection = factory.newConnection();
    com.rabbitmq.client.Channel channel = connection.createChannel();
    String corrId = java.util.UUID.randomUUID().toString();

    LoanRequestDTO loanRequest = new LoanRequestDTO("123456-7890", 456289.0, 25, -1);

    Gson gson = new Gson();

    String message = gson.toJson(loanRequest);

    AMQP.BasicProperties props = new AMQP.BasicProperties.Builder().correlationId(corrId).build();
    channel.queueDeclare(TASK_QUEUE_NAME, true, false, false, null);

    channel.basicPublish("", TASK_QUEUE_NAME, props, message.getBytes());

    channel.close();/*from w ww  . jav  a2 s .  c om*/
    connection.close();
}

From source file:edu.iit.rabbitmq.Queue.java

/**
 *
 * @return//  ww w . ja  va2s .c om
 */
protected Channel getChannel() {
    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost(RABBITMQ);
    Channel channel = null;
    try {
        Connection connection = factory.newConnection();
        channel = connection.createChannel();
        channel.queueDeclare(QUEUENAME, false, false, false, null);
    } catch (Exception e) {
        System.out.println("Queue already exists, moving on");
    }
    return channel;
}

From source file:edu.iit.rabbitmq.Send.java

/**
 *
 * @param message/*from   ww w. ja v a2 s  .  co m*/
 * @throws Exception
 */
public void sendMessage(String message) throws Exception {

    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost(RABBITMQ);
    Connection connection = factory.newConnection();
    Channel channel = connection.createChannel();
    try {
        channel.queueDeclare(QUEUENAME, false, false, false, null);
    } catch (Exception e) {
        System.out.println("Queue already exists, moving on");
    }

    channel.basicPublish("", QUEUENAME, null, message.getBytes("UTF-8"));
    System.out.println(" [x] Sent '" + message + "'");

    channel.close();
    connection.close();
}

From source file:edu.indiana.d2i.sead.matchmaker.service.messaging.Receiver.java

License:Apache License

Receiver(MessagingConfig msgconf) throws IOException {
    this.factory = new ConnectionFactory();
    this.factory.setUsername(msgconf.getUsername());
    this.factory.setPassword(msgconf.getPassword());
    this.factory.setVirtualHost(msgconf.getVirtualHost());
    this.factory.setHost(msgconf.getHost());
    this.factory.setPort(msgconf.getPort());

    this.ExchangeName = msgconf.getBaseExchangeName();
    this.QueueName = msgconf.getBaseQueueName();
    this.RoutingKey = msgconf.getBaseRoutingKey();
    createConnection();//from  w  ww . ja v  a 2 s . c  o  m
    createChannel();
    formatChannel();

}

From source file:edu.indiana.d2i.sead.matchmaker.service.messaging.Receiver.java

License:Apache License

public Receiver(MessagingConfig msgconf, MessagingOperationTypes OpType) throws IOException {
    this.factory = new ConnectionFactory();
    this.factory.setUsername(msgconf.getUsername());
    this.factory.setPassword(msgconf.getPassword());
    this.factory.setVirtualHost(msgconf.getVirtualHost());
    this.factory.setHost(msgconf.getHost());
    this.factory.setPort(msgconf.getPort());

    switch (OpType) {
    case RECEIVE_ASYNC_REQUEST:
        this.ExchangeName = msgconf.getAsyncRequestExchangeName();
        this.QueueName = msgconf.getAsyncRequestQueueName();
        this.RoutingKey = msgconf.getAsyncRequestRoutingKey();
        break;//from w  w w. j a  va  2  s .c o m
    case RECEIVE_REQUESTS:
        this.ExchangeName = msgconf.getRequestExchangeName();
        this.QueueName = msgconf.getRequestQueueName();
        this.RoutingKey = msgconf.getRequestRoutingKey();
        break;
    case RECEIVE_RESPONSE:
        this.ExchangeName = msgconf.getResponseExchangeName();
        this.QueueName = msgconf.getResponseQueueName();
        this.RoutingKey = msgconf.getResponseRoutingKey();
        break;
    default:
        try {
            throw new Exception("OperationType: " + OpType.toString() + " not supported.");
        } catch (Exception e) {
            // TODO Auto-generated catch block
            e.printStackTrace();
        }
        break;
    }

    createConnection();
    createChannel();
    formatChannel();

}

From source file:edu.indiana.d2i.sead.matchmaker.service.messaging.Sender.java

License:Apache License

public Sender(MessagingConfig msgconf) throws IOException {
    this.factory = new ConnectionFactory();
    this.factory.setUsername(msgconf.getUsername());
    this.factory.setPassword(msgconf.getPassword());
    this.factory.setVirtualHost(msgconf.getVirtualHost());
    this.factory.setHost(msgconf.getHost());
    this.factory.setPort(msgconf.getPort());

    this.conn = this.factory.newConnection();
    this.channel = this.conn.createChannel();
    this.ExchangeName = msgconf.getBaseExchangeName();
    this.RoutingKey = msgconf.getBaseRoutingKey();

}