Example usage for com.rabbitmq.client ShutdownListener interface-usage

List of usage examples for com.rabbitmq.client ShutdownListener interface-usage

Introduction

In this page you can find the example usage for com.rabbitmq.client ShutdownListener interface-usage.

Usage

From source file com.abiquo.commons.amqp.config.ChannelHandler.java

public abstract class ChannelHandler implements ShutdownListener {
    private ConnectionFactory connectionFactory;

    private Connection connection;

    private Channel channel;

From source file com.googlesource.gerrit.plugins.rabbitmq.AMQPSession.java

public class AMQPSession implements ShutdownListener {

    private static final Logger LOGGER = LoggerFactory.getLogger(AMQPSession.class);
    private final Properties properties;
    private volatile Connection connection;
    private volatile Channel publishChannel;

From source file com.shopwiki.roger.RabbitReconnector.java

/**
 * Used to re-establish a Connection to a RabbitMQ when a connection breaks.
 * Add an instance of this a Connection to use it.
 *
 * @author rstewart
 */

From source file com.sonymobile.jenkins.plugins.mq.mqnotifier.MQConnection.java

/**
 * Creates an MQ connection.
 *
 * @author rjan Percy <orjan.percy@sonymobile.com>
 */
public final class MQConnection implements ShutdownListener {

From source file io.qdb.server.input.RabbitMQInputHandler.java

/**
 * Fetches messages from a RabbitMQ queue.
 */
public class RabbitMQInputHandler extends InputHandlerAdapter implements ShutdownListener {

    public String exchange;

From source file io.qdb.server.output.RabbitMQOutputHandler.java

/**
 * Published messages to a RabbitMQ server.
 */
public class RabbitMQOutputHandler extends OutputHandlerAdapter implements ShutdownListener {

    public String exchange;

From source file it.txt.ens.authorisationService.util.AccessRequestEvaluator.java

/**
 * This class evaluates an access request and send back to the service requester
 * a message with the processing outcome.
 * 
 * @author Carbone Matteo
 * @author Salvatore Piccione (TXT e-solutions SpA - salvatore.piccione AT network.txtgroup.com)

From source file it.txt.ens.authorisationService.util.AccessRequestListener.java

/**
 * This class defines a subscriber listening to access requests (actually RPC-over-AMQP messages).
 * 
 * @author Carbone Matteo
 * @author Salvatore Piccione (TXT e-solutions SpA - salvatore.piccione AT network.txtgroup.com)
 */

From source file org.graylog2.inputs.amqp.AMQPReconnector.java

/**
 * @author Lennart Koopmann <lennart@socketfeed.com>
 */
public class AMQPReconnector implements ShutdownListener {

    private static final Logger LOG = LoggerFactory.getLogger(AMQPReconnector.class);

From source file org.objectweb.joram.mom.dest.amqp.LiveServerConnection.java

/**
 * A {@link LiveServerConnection} keeps alive a connection to an AMQP server.
 * When the connection fails, a reconnection routine starts.
 */
public class LiveServerConnection implements LiveServerConnectionMBean, ShutdownListener, Serializable {