Example usage for com.rabbitmq.client ConnectionFactory setUsername

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

Introduction

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

Prototype

public void setUsername(String username) 

Source Link

Document

Set the user name.

Usage

From source file:dk.au.cs.karibu.producer.rabbitmq.RabbitChannelConnector.java

License:Apache License

@Override
public void openConnection() throws IOException {
    theLogger.info("openConnection: " + exchangeConfiguration);
    ConnectionFactory factory = new ConnectionFactory();
    factory.setUsername(exchangeConfiguration.getUsername());
    factory.setPassword(exchangeConfiguration.getPassword());
    if (exchangeConfiguration.isSSLConnection()) {
        try {//from w  w  w . j  a v a2s . com
            factory.useSslProtocol();
        } catch (KeyManagementException e) {
            theLogger.error("KeyManagementException: " + e.getLocalizedMessage());
        } catch (NoSuchAlgorithmException e) {
            theLogger.error("NoSuchAlgorithmException: " + e.getLocalizedMessage());
        }
    }
    connection = factory.newConnection(exchangeConfiguration.getServerAddressList());

    channel = connection.createChannel();
    channel.exchangeDeclare(exchangeConfiguration.getExchangeName(), exchangeConfiguration.getExchangeType(),
            exchangeConfiguration.isExchangeDurable());

    // The queue and the binding between queue and exchange is defined by the server side! 
}

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

public static HashMap<String, Object> setUpReceiver() throws java.io.IOException, TimeoutException {
    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);//  w ww .j  av  a  2  s  . c om

    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:dk.bankjsonrabbit.messaging.Send.java

public static void sendMessage(String message, BasicProperties props) throws IOException, TimeoutException {
    String taskQueueName = props.getReplyTo();

    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(taskQueueName, true, false, false, null);

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

    channel.close();//w  w w. j a  v  a2s .  c om
    connection.close();
}

From source file:dk.getcreditscore.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  a2s .  co m

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

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

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

    return returnObjects;
}

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();/* ww  w.j a v  a2s .c o m*/
    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 ww  w . j  a  va2  s . 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 ww  .j  a v a 2s .co m
 */
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/* ww  w . j a va2  s.  c  o m*/
        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();//w ww. ja v a2  s.  c  om
    connection.close();
}

From source file:eu.europeana.servicebus.client.rabbitmq.RabbitMQClientAsync.java

/**
 * RabbitMQ implementation of ESBClient//  ww  w. j a  va  2 s  .  co m
 *
 * @param host The host to connect to
 * @param incomingQueue The incoming queue
 * @param outgoingQueue The outgoing queue
 * @param username Username
 * @param password Password
 * @param consumer The consumer implementation - It can be null. It allows asynchronous consumers as well as enables
 * custom behaviour handling upon incoming message. The default message handling is and should be agnostic of the
 * method semantics to be implemented
 * @throws IOException
 */
public RabbitMQClientAsync(String host, String incomingQueue, String outgoingQueue, String username,
        String password, Consumer consumer) throws IOException {
    this.host = host;
    this.incomingQueue = incomingQueue;
    this.outgoingQueue = outgoingQueue;
    this.username = username;
    this.password = password;
    if (consumer == null) {
        this.consumer = new DefaultConsumer(receiveChannel);
    } else {
        this.consumer = consumer;
    }
    ConnectionFactory factory = new ConnectionFactory();
    builder = new AMQP.BasicProperties.Builder();
    factory.setHost(host);
    factory.setUsername(username);
    factory.setPassword(password);

    connection = factory.newConnection();
    sendChannel = connection.createChannel();
    receiveChannel = connection.createChannel();
    sendChannel.queueDeclare(outgoingQueue, true, false, false, null);
    receiveChannel.queueDeclare(incomingQueue, true, false, false, null);
    receiveChannel.basicConsume(incomingQueue, true, consumer);

}