RabbitMQ

pillars.rabbitmq.fs2.RabbitMQ
See theRabbitMQ companion object
final case class RabbitMQ[F[_]](config: RabbitMQConfig, client: RabbitClient[F])(implicit evidence$1: Async[F]) extends Module[F]

Attributes

Companion
object
Graph
Supertypes
trait Serializable
trait Product
trait Equals
trait Module[F]
class Object
trait Matchable
class Any
Show all

Members list

Type members

Types

override type ModuleConfig = RabbitMQConfig

Value members

Concrete methods

override def probes: List[Probe[F]]

Attributes

Definition Classes

Inherited methods

Attributes

Inherited from:
Module
def productElementNames: Iterator[String]

Attributes

Inherited from:
Product
def productIterator: Iterator[Any]

Attributes

Inherited from:
Product

Exports

Defined exports

val binding: Binding[RabbitClient.this.F]
Exported from RabbitClient
val connection: ConnectionResource[RabbitClient.this.F]
Exported from RabbitClient
val consumingProgram: AckConsumingProgram[RabbitClient.this.F]
Exported from RabbitClient
def createBasicPublisher[A](implicit channel: AMQPChannel, encoder: MessageEncoder[RabbitClient.this.F, A]): RabbitClient.this.F[(ExchangeName, RoutingKey, A) => RabbitClient.this.F[Unit]]
Exported from RabbitClient
def createConnection: Resource[RabbitClient.this.F, AMQPConnection]
Exported from RabbitClient
def createConnectionChannel: Resource[RabbitClient.this.F, AMQPChannel]
Exported from RabbitClient
val declaration: Declaration[RabbitClient.this.F]
Exported from RabbitClient
val deletion: Deletion[RabbitClient.this.F]
Exported from RabbitClient
val publishingProgram: PublishingProgram[RabbitClient.this.F]
Exported from RabbitClient