Package | Description |
---|---|
com.rabbitmq.client |
The client API proper: classes and interfaces representing the AMQP
connections, channels, and wire-protocol framing descriptors.
|
com.rabbitmq.client.impl |
Implementations of interfaces specified in the client API, and their supporting classes.
|
com.rabbitmq.client.impl.recovery |
Implementation of connection and topology recovery.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RecoverableConnection
Convenient interface when working against auto-recovery connections.
|
Modifier and Type | Method and Description |
---|---|
Connection |
Channel.getConnection()
Retrieve the connection which carries this channel.
|
Connection |
ConnectionFactory.newConnection()
Create a new broker connection.
|
Connection |
ConnectionFactory.newConnection(Address[] addrs)
Create a new broker connection, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(Address[] addrs,
String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(AddressResolver addressResolver)
Create a new broker connection, picking the first available address from
the list provided by the
AddressResolver . |
Connection |
ConnectionFactory.newConnection(ExecutorService executor)
Create a new broker connection.
|
Connection |
ConnectionFactory.newConnection(ExecutorService executor,
Address[] addrs)
Create a new broker connection, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(ExecutorService executor,
Address[] addrs,
String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(ExecutorService executor,
AddressResolver addressResolver)
Create a new broker connection, picking the first available address from
the list provided by the
AddressResolver . |
Connection |
ConnectionFactory.newConnection(ExecutorService executor,
AddressResolver addressResolver,
String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from
the list provided by the
AddressResolver . |
Connection |
ConnectionFactory.newConnection(ExecutorService executor,
List<Address> addrs)
Create a new broker connection, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(ExecutorService executor,
List<Address> addrs,
String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(ExecutorService executor,
String connectionName)
Create a new broker connection.
|
Connection |
ConnectionFactory.newConnection(List<Address> addrs)
Create a new broker connection, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(List<Address> addrs,
String clientProvidedName)
Create a new broker connection with a client-provided name, picking the first available address from
the list.
|
Connection |
ConnectionFactory.newConnection(String connectionName)
Create a new broker connection.
|
Modifier and Type | Method and Description |
---|---|
void |
NoOpMetricsCollector.closeConnection(Connection connection) |
void |
MetricsCollector.closeConnection(Connection connection) |
void |
ExceptionHandler.handleBlockedListenerException(Connection connection,
Throwable exception)
Perform any required exception processing for the situation
when the driver thread for the connection has called a
BlockedListener's method, and that method has
thrown an exception.
|
void |
ExceptionHandler.handleConnectionRecoveryException(Connection conn,
Throwable exception)
Perform any required exception processing for the situation
when the driver thread for the connection has an exception
during connection recovery that it can't otherwise deal with.
|
void |
ExceptionHandler.handleTopologyRecoveryException(Connection conn,
Channel ch,
TopologyRecoveryException exception)
Perform any required exception processing for the situation
when the driver thread for the connection has an exception
during topology (exchanges, queues, bindings, consumers) recovery
that it can't otherwise deal with.
|
void |
ExceptionHandler.handleUnexpectedConnectionDriverException(Connection conn,
Throwable exception)
Perform any required exception processing for the situation
when the driver thread for the connection has an exception
signalled to it that it can't otherwise deal with.
|
void |
NoOpMetricsCollector.newConnection(Connection connection) |
void |
MetricsCollector.newConnection(Connection connection) |
Modifier and Type | Class and Description |
---|---|
class |
AMQConnection
Concrete class representing and managing an AMQP connection to a broker.
|
Modifier and Type | Method and Description |
---|---|
void |
AbstractMetricsCollector.closeConnection(Connection connection) |
protected abstract void |
AbstractMetricsCollector.decrementConnectionCount(Connection connection)
Decrements connection count.
|
protected void |
MicrometerMetricsCollector.decrementConnectionCount(Connection connection) |
protected void |
StandardMetricsCollector.decrementConnectionCount(Connection connection) |
protected void |
OpenTelemetryMetricsCollector.decrementConnectionCount(Connection connection) |
void |
ErrorOnWriteListener.handle(Connection connection,
IOException exception)
Called when writing to the socket failed
|
void |
StrictExceptionHandler.handleBlockedListenerException(Connection connection,
Throwable exception) |
void |
ForgivingExceptionHandler.handleBlockedListenerException(Connection connection,
Throwable exception) |
protected void |
ForgivingExceptionHandler.handleConnectionKiller(Connection connection,
Throwable exception,
String what) |
void |
ForgivingExceptionHandler.handleConnectionRecoveryException(Connection conn,
Throwable exception) |
void |
ForgivingExceptionHandler.handleTopologyRecoveryException(Connection conn,
Channel ch,
TopologyRecoveryException exception) |
void |
ForgivingExceptionHandler.handleUnexpectedConnectionDriverException(Connection conn,
Throwable exception) |
protected abstract void |
AbstractMetricsCollector.incrementConnectionCount(Connection connection)
Increments connection count.
|
protected void |
MicrometerMetricsCollector.incrementConnectionCount(Connection connection) |
protected void |
StandardMetricsCollector.incrementConnectionCount(Connection connection) |
protected void |
OpenTelemetryMetricsCollector.incrementConnectionCount(Connection connection) |
void |
AbstractMetricsCollector.newConnection(Connection connection) |
Modifier and Type | Class and Description |
---|---|
class |
AutorecoveringConnection
Connection implementation that performs automatic recovery when
connection shutdown is not initiated by the application (e.g.
|
class |
RecoveryAwareAMQConnection
AMQConnection modification that uses RecoveryAwareChannelN |
Modifier and Type | Method and Description |
---|---|
Connection |
AutorecoveringChannel.getConnection() |
Modifier and Type | Method and Description |
---|---|
void |
AutorecoveringChannel.automaticallyRecover(AutorecoveringConnection connection,
Connection connDelegate) |
Copyright © 2022 VMware, Inc. or its affiliates.. All rights reserved.