Example usage for com.rabbitmq.client ConnectionFactory setHost

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

Introduction

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

Prototype

public void setHost(String host) 

Source Link

Usage

From source file:com.loanbroker.old.JSONSendTest.java

public static void main(String[] argv) 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.exchangeDeclare(EXCHANGE_NAME, "fanout");
    String queueName = "Kender du hende der Arne";
    channel.queueDeclare(queueName, false, false, false, null);

    channel.queueBind(queueName, EXCHANGE_NAME, "");
    String messageOut = "{\"ssn\":1605789787,\"creditScore\":699,\"loanAmount\":10.0,\"loanDuration\":360}";
    BasicProperties.Builder props = new BasicProperties().builder();
    props.replyTo("");
    BasicProperties bp = props.build();/*from w  w w .  ja  v  a 2 s . c  o m*/
    channel.basicPublish(EXCHANGE_NAME, "", bp, messageOut.getBytes());
    System.out.println(" [x] Sent by JSONtester: '" + messageOut + "'");

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

From source file:com.lumlate.midas.email.GmailReader.java

License:Apache License

/**
 * Authenticates to IMAP with parameters passed in on the commandline.
 *///  w w w  . j av  a2  s . c  om
public static void main(String args[]) throws Exception {

    String mysqlhost = "localhost";
    String mysqlport = "3306";
    String mysqluser = "lumlate";
    String mysqlpassword = "lumlate$";
    String database = "lumlate";
    MySQLAccess myaccess = new MySQLAccess(mysqlhost, mysqlport, mysqluser, mysqlpassword, database);

    String email = "sharmavipul@gmail.com";
    String oauthToken = "1/co5CyT8QrJXyJagK5wzWNGZk2RTA0FU_dF9IhwPvlBs";
    String oauthTokenSecret = "aK5LCYOFrUweFPfMcPYNXWzg";
    String TASK_QUEUE_NAME = "gmail_oauth";
    String rmqserver = "rmq01.deallr.com";

    initialize();
    IMAPSSLStore imapSslStore = connectToImap("imap.googlemail.com", 993, email, oauthToken, oauthTokenSecret,
            getDeallrConsumer(), true);
    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost(rmqserver);
    factory.setUsername("lumlate");
    factory.setPassword("lumlate$");
    Connection connection = factory.newConnection();
    Channel channel = connection.createChannel();

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

    Folder folder = imapSslStore.getFolder("INBOX");//get inbox
    folder.open(Folder.READ_WRITE);//open folder only to read
    SearchTerm flagterm = new FlagTerm(new Flags(Flags.Flag.SEEN), false);

    RetailersDAO retaildao = new RetailersDAO();
    retaildao.setStmt(myaccess.getConn().createStatement());
    LinkedList<String> retaildomains = retaildao.getallRetailerDomains();
    LinkedList<SearchTerm> searchterms = new LinkedList<SearchTerm>();
    for (String retaildomain : retaildomains) {
        SearchTerm retailsearchterm = new FromStringTerm(retaildomain);
        searchterms.add(retailsearchterm);
    }
    SearchTerm[] starray = new SearchTerm[searchterms.size()];
    searchterms.toArray(starray);
    SearchTerm st = new OrTerm(starray); //TODO add date to this as well so that fetch is since last time
    SearchTerm searchterm = new AndTerm(st, flagterm);

    Message message[] = folder.search(searchterm);
    for (int i = 0; i < message.length; i++) {
        Message msg = message[i];
        ByteArrayOutputStream bos = new ByteArrayOutputStream();
        msg.writeTo(bos);
        byte[] buf = bos.toByteArray();
        channel.basicPublish("", TASK_QUEUE_NAME, MessageProperties.PERSISTENT_TEXT_PLAIN, buf);
    }
    myaccess.Dissconnect();
    channel.close();
    connection.close();
}

From source file:com.lumlate.midas.email.InboxReader.java

License:Apache License

public Boolean readInbox(Properties props, String protocol, String hostname, String username, String password,
        Date lastfetch, String TASK_QUEUE_NAME) throws Exception {
    String rmqserver = props.getProperty("com.lumlate.midas.rmq.server");
    String rmqusername = props.getProperty("com.lumlate.midas.rmq.username");
    String rmqpassword = props.getProperty("com.lumlate.midas.rmq.password");

    ConnectionFactory factory = new ConnectionFactory();
    factory.setUsername(rmqusername);//  w  ww.j a v a 2  s .  c  om
    factory.setPassword(rmqpassword);
    factory.setHost(rmqserver);
    Connection connection = factory.newConnection();
    Channel channel = connection.createChannel();
    channel.queueDeclare(TASK_QUEUE_NAME, true, false, false, null);

    Session session = Session.getDefaultInstance(props, null);
    // session.setDebug(true);
    // session.setDebugOut(System.out);
    Store store = session.getStore(protocol);
    store.connect(hostname, username, password);
    // Folder folder = store.getFolder("Inbox");// get inbox
    Folder folder = store.getDefaultFolder();
    folder.open(Folder.READ_WRITE);
    Folder deallrfolder = store.getFolder("Deallr");
    // if (!deallrfolder.exists()) {
    try {
        deallrfolder.create(Folder.HOLDS_MESSAGES);
    } catch (Exception err) {
        System.out.println("Cannot create Folder");
        err.printStackTrace();
    }
    // }

    // SearchTerm flagterm = new FlagTerm(new Flags(Flags.Flag.SEEN),
    // false);

    SearchTerm[] starray = new SearchTerm[searchterms.size()];
    searchterms.toArray(starray);
    SearchTerm st = new OrTerm(starray); // TODO add date to this as
    SearchTerm newerThen; // well so
    // that fetch is since last time
    if (lastfetch != null) {
        newerThen = new ReceivedDateTerm(ComparisonTerm.GT, lastfetch);
        // st = new AndTerm(st, flagterm);
        st = new AndTerm(st, newerThen);
    } else {
        newerThen = new ReceivedDateTerm(ComparisonTerm.GT, fetchsince);
        // st = new AndTerm(st, flagterm);
        st = new AndTerm(st, newerThen);
    }
    try {
        Message message[] = folder.search(st);
        for (int i = 0; i < message.length; i++) {
            Message msg = message[i];
            folder.copyMessages(new Message[] { msg }, deallrfolder);
            msg.setFlag(Flag.SEEN, true);
            ByteArrayOutputStream bos = new ByteArrayOutputStream();
            msg.writeTo(bos);
            byte[] buf = bos.toByteArray();
            channel.basicPublish("", TASK_QUEUE_NAME, MessageProperties.PERSISTENT_TEXT_PLAIN, buf);
        }
    } catch (Exception err) {
        err.printStackTrace();
        throw new Exception(err.getMessage());
    }

    folder.close(true);
    store.close();
    channel.close();
    connection.close();
    return true;
}

From source file:com.lumlate.midas.email.InboxReader.java

License:Apache License

public Boolean readOauthInbox(Properties props, String scope, String email, String oauthToken,
        String oauthTokenSecret, Date lastfetch, String TASK_QUEUE_NAME, String fetchtype) throws Exception {
    String rmqserver = props.getProperty("com.lumlate.midas.rmq.server");
    String rmqusername = props.getProperty("com.lumlate.midas.rmq.username");
    String rmqpassword = props.getProperty("com.lumlate.midas.rmq.password");

    ConnectionFactory factory = new ConnectionFactory();
    factory.setUsername(rmqusername);//from   ww  w  .jav  a2  s  .  c o m
    factory.setPassword(rmqpassword);
    factory.setHost(rmqserver);
    Connection connection = factory.newConnection();
    Channel channel = connection.createChannel();
    channel.queueDeclare(TASK_QUEUE_NAME, true, false, false, null);

    Store imapSslStore = XoauthAuthenticator.connectToImap("imap.googlemail.com", 993, email, oauthToken,
            oauthTokenSecret, XoauthAuthenticator.getDeallrConsumer(), true);

    SearchTerm[] starray = new SearchTerm[searchterms.size()];
    searchterms.toArray(starray);
    SearchTerm st = new OrTerm(starray); // TODO add date to this as
    SearchTerm newerThen;
    // that fetch is since last time
    if (lastfetch != null) {
        newerThen = new ReceivedDateTerm(ComparisonTerm.GT, lastfetch);
        st = new AndTerm(st, newerThen);
    } else {
        newerThen = new ReceivedDateTerm(ComparisonTerm.GT, fetchsince);
        st = new AndTerm(st, newerThen);
    }

    Folder folder = imapSslStore.getFolder("[Gmail]/All Mail");// get inbox
    folder.open(Folder.READ_WRITE);
    //Folder deallrfolder=null;
    //if(fetchtype.equalsIgnoreCase("scheduler")){
    //deallrfolder = imapSslStore.getFolder("Deallr");
    //if (!deallrfolder.exists())
    //   deallrfolder.create(Folder.HOLDS_MESSAGES);         
    //}
    try {
        Message message[] = folder.search(st);
        for (int i = 0; i < message.length; i++) {
            Message msg = message[i];
            msg.setFlag(Flag.SEEN, true);
            ByteArrayOutputStream bos = new ByteArrayOutputStream();
            msg.writeTo(bos);
            byte[] buf = bos.toByteArray();
            channel.basicPublish("", TASK_QUEUE_NAME, MessageProperties.PERSISTENT_TEXT_PLAIN, buf);
            //if(deallrfolder!=null){
            //   folder.copyMessages(new Message[] { msg }, deallrfolder);
            //}
        }
    } catch (Exception err) {
        err.printStackTrace();
        throw new Exception(err.getMessage());
    }

    folder.close(true);
    //deallrfolder.close(true);
    imapSslStore.close();
    channel.close();
    connection.close();
    return true;
}

From source file:com.magikbyte.smalldoode.meeting.Manager.java

public void init() {
    try {//  ww  w .j a v  a2s  .c o m
        ConnectionFactory factory = new ConnectionFactory();
        factory.setHost("localhost");
        Connection connection = factory.newConnection();
        Channel channel = connection.createChannel();
        channel.queueDeclare(QUEUE_NAME, false, false, false, null);

        consumer = new DefaultConsumer(channel) {
            @Override
            public void handleDelivery(String consumerTag, Envelope envelope, AMQP.BasicProperties properties,
                    byte[] body) throws IOException {
                String message = new String(body, "UTF-8");
                dispatchMessage(message);
            }
        };
        channel.basicConsume(QUEUE_NAME, true, consumer);
    } catch (IOException | TimeoutException e) {
    }
}

From source file:com.magikbyte.smalldoode.meeting.model.Agent.java

public void init() {
    try {// w  w  w  .  j  av  a 2  s.  c o m
        ConnectionFactory factory = new ConnectionFactory();
        factory.setHost("localhost");
        connection = factory.newConnection();
        channel = connection.createChannel();
        channel.exchangeDeclare(Manager.QUEUE_NAME, "fanout");
        String message = "msg," + this.name + " est connect au groupe";
        sendMsgToTopic(message);
    } catch (IOException | TimeoutException e) {
    }
}

From source file:com.magikbyte.smalldoode.meeting.model.Groupe.java

public void init() {
    try {/*from   www.j  a  v a  2s  .  c o  m*/
        ConnectionFactory factory = new ConnectionFactory();
        factory.setHost("localhost");
        connection = factory.newConnection();
        channel = connection.createChannel();
        channel.exchangeDeclare(this.name, "topic");
        String queueName = channel.queueDeclare().getQueue();
        channel.queueBind(queueName, this.name, this.name);
        System.out.println(" [*] Waiting for messages. To exit press CTRL+C");

        Consumer consumer = new DefaultConsumer(channel) {
            @Override
            public void handleDelivery(String consumerTag, Envelope envelope, AMQP.BasicProperties properties,
                    byte[] body) throws IOException {
                String[] msg;
                String message = new String(body, "UTF-8");
                if (message.startsWith("msg,")) {
                    messages.add(message);

                } else if (message.startsWith("dateAdmin")) {

                    if (dateProposeParAdmin.size() < maxChoixPossiblePourUneReunion) {
                        message = message.replace("dateAdmin,", "");
                        dateProposeParAdmin.add(message.split(",")[1]);
                    }

                } else if (message.startsWith("dateUser")) {
                    message = message.replace("dateUser,", "");
                    msg = message.split(",");
                    List<String> mesMessages = dateProposeParLesAgents.get(msg[0].trim());
                    if (mesMessages == null) {
                        mesMessages = new ArrayList<>();
                    }
                    mesMessages.add(msg[1]);
                    dateProposeParLesAgents.put(msg[0].trim(), mesMessages);
                }

                setChanged();
                notifyObservers();
                System.out.println(" [x] Received " + message);
            }
        };
        channel.basicConsume(queueName, true, consumer);
    } catch (IOException | TimeoutException e) {
        e.printStackTrace();
    }

}

From source file:com.magikbyte.smalldoode.meeting.views.ManagerView.java

public void init() {
    try {/* w w  w. ja va  2 s.co  m*/
        ConnectionFactory factory = new ConnectionFactory();
        factory.setHost("localhost");
        connection = factory.newConnection();
        channel = connection.createChannel();
        channel.queueDeclare(Manager.QUEUE_NAME, false, false, false, null);
    } catch (IOException ex) {
        Logger.getLogger(ManagerView.class.getName()).log(Level.SEVERE, null, ex);
    } catch (TimeoutException ex) {
        Logger.getLogger(ManagerView.class.getName()).log(Level.SEVERE, null, ex);
    }
}

From source file:com.modeln.batam.connector.Connector.java

License:Open Source License

/**
 * Begin a connection using parameters. If some or all parameters are null, the connector will use values loaded either from property files or System properties.
 * //from  ww w. j ava2  s .c o m
 * If no system property have been defined using {@see System#setProperty(String, String) setProperty}, This method will use configuration located in the batam.properties file by default.
 * Non null parameters will override default property file values.
 * 
 * To use external property file properties, call {@see com.modeln.batam.connector.Connector#loadProperties(String) loadProperties} function specifying the external property file location before to call this method with null parameters. 
 * 
 * If System properties are defined, they will override values defined in property files (default or external). Non null parameters will also override System properties.
 * 
 * @param host : message broker host configuration.
 * @param username : message broker user name configuration.
 * @param password : message broker password configuration. 
 * @param port : message broker port configuration.
 * @param vhost : message broker VHost configuration.
 * @param queue : message broker queue the connector publish data to.
 * @param publisher : when set to 'off', it prints messages in your console (stdout) instead of publishing them to the message broker. 
 * 
 * @throws IOException
 */
@RetryOnFailure(attempts = RETRY_ON_FAILURE_ATTEMPTS, delay = RETRY_ON_FAILURE_DELAY, unit = TimeUnit.SECONDS)
public void beginConnection(String host, String username, String password, Integer port, String vhost,
        String queue, String publisher) throws IOException {
    ConfigHelper.loadProperties(null);

    if (host == null && this.host == null) {
        this.host = ConfigHelper.HOST;
    } else if (host != null) {
        this.host = host;
    }

    if (username == null && this.username == null) {
        this.username = ConfigHelper.USER;
    } else if (username != null) {
        this.username = username;
    }

    if (password == null && this.password == null) {
        this.password = ConfigHelper.PASSWORD;
    } else if (password != null) {
        this.password = password;
    }

    if (port == null && this.port == null) {
        this.port = ConfigHelper.PORT;
    } else if (port != null) {
        this.port = port;
    }

    if (vhost == null && this.vhost == null) {
        this.vhost = ConfigHelper.VHOST;
    } else if (vhost != null) {
        this.vhost = vhost;
    }

    if (queue == null && this.queue == null) {
        this.queue = ConfigHelper.QUEUE;
    } else if (queue != null) {
        this.queue = queue;
    }

    if (publisher == null) {
        publisher = ConfigHelper.PUBLISHER;
    }
    if ("on".equals(publisher) || "true".equals(publisher)) {
        this.publish = true;
    } else {
        this.publish = false;
        return;
    }

    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost(this.host);
    factory.setPort(this.port);
    factory.setUsername(this.username);
    factory.setPassword(this.password);
    factory.setVirtualHost(this.vhost);
    this.connection = factory.newConnection();
    this.channel = this.connection.createChannel();
    this.channel.queueDeclare(this.queue, false, false, false, null);
}

From source file:com.mycompany.aggregator.Aggregator.java

public void subscribe() throws Exception, TimeoutException, IOException {
    ConnectionFactory factory = new ConnectionFactory();
    factory.setHost("localhost");
    factory.setUsername(USERNAME);//from   w  w w .j a  va  2 s  .  c  o m
    factory.setPassword(PASSWORD);

    Connection connection = factory.newConnection();
    Channel channel = connection.createChannel();

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

    Consumer consumer = new DefaultConsumer(channel) {
        @Override
        public void handleDelivery(String consumerTag, Envelope envelope, AMQP.BasicProperties properties,
                byte[] body) throws IOException {
            String response = new String(body, "UTF-8");

            System.out.println("Received message!!");

            synchronized (responseQueueBuffer) {
                if (responseQueueBuffer.get(properties.getCorrelationId()) == null) {
                    responseQueueBuffer.put(properties.getCorrelationId(), new ResponseBuffer());
                }
                if (response != null) {
                    responseQueueBuffer.get(properties.getCorrelationId())
                            .addResponse(new JSONObject(response));
                }
            }
        }
    };

    channel.basicConsume(QUEUE_NAME, true, consumer);

    Thread task = new Thread() {
        @Override
        public void run() {
            while (true) {
                syncQueues();
                for (Map.Entry<String, ResponseBuffer> pair : responseQueue.entrySet()) {
                    if (responseQueue.get(pair.getKey()).getCreatedAt() + TIMEOUT < System
                            .currentTimeMillis()) {
                        JSONObject bestResponse = responseQueue.get(pair.getKey()).getBestResponse();
                        try {
                            forwardToSockets(bestResponse, (String) pair.getKey());
                            System.out.println("Should return " + bestResponse);
                            responseQueue.get(pair.getKey()).setFinished();
                        } catch (IOException ex) {
                            Logger.getLogger(Aggregator.class.getName()).log(Level.SEVERE, null, ex);
                        } catch (TimeoutException ex) {
                            Logger.getLogger(Aggregator.class.getName()).log(Level.SEVERE, null, ex);
                        }

                    }
                }
            }
        }

    };
    task.start();
}