Agent Skills: Messaging & Event-Driven Skill

Message queues and event-driven backend architecture. RabbitMQ, Kafka, pub/sub patterns, and async communication.

rabbitmqkafkapub-subasync-communicationmessage-queue
backendID: pluginagentmarketplace/custom-plugin-backend/messaging

Skill Files

Browse the full folder contents for messaging.

Download Skill

Loading file tree…

skills/messaging/SKILL.md

Skill Metadata

Name
messaging
Description
Message queues and event-driven backend architecture. RabbitMQ, Kafka, pub/sub patterns, and async communication.

Messaging & Event-Driven Skill

Bonded to: architecture-patterns-agent (Secondary)


Quick Start

# Invoke messaging skill
"Set up RabbitMQ for my microservices"
"Implement event-driven order processing"
"Configure Kafka for high-throughput messaging"

Message Broker Comparison

| Broker | Best For | Throughput | Ordering | |--------|----------|------------|----------| | RabbitMQ | Task queues, RPC | Medium | Per queue | | Kafka | Event streaming, logs | Very high | Per partition | | Redis Pub/Sub | Real-time, simple | High | None | | SQS | AWS serverless | Medium | FIFO optional |


Examples

RabbitMQ Producer/Consumer

import pika
import json

# Producer
connection = pika.BlockingConnection(pika.ConnectionParameters('localhost'))
channel = connection.channel()
channel.queue_declare(queue='orders', durable=True)

def publish_order(order):
    channel.basic_publish(
        exchange='',
        routing_key='orders',
        body=json.dumps(order),
        properties=pika.BasicProperties(delivery_mode=2)  # persistent
    )

# Consumer
def process_order(ch, method, properties, body):
    order = json.loads(body)
    print(f"Processing order: {order['id']}")
    ch.basic_ack(delivery_tag=method.delivery_tag)

channel.basic_qos(prefetch_count=1)
channel.basic_consume(queue='orders', on_message_callback=process_order)
channel.start_consuming()

Kafka Event Streaming

from kafka import KafkaProducer, KafkaConsumer
import json

# Producer
producer = KafkaProducer(
    bootstrap_servers=['localhost:9092'],
    value_serializer=lambda v: json.dumps(v).encode('utf-8')
)

producer.send('user-events', {'type': 'USER_CREATED', 'user_id': '123'})

# Consumer
consumer = KafkaConsumer(
    'user-events',
    bootstrap_servers=['localhost:9092'],
    group_id='notification-service',
    auto_offset_reset='earliest',
    value_deserializer=lambda m: json.loads(m.decode('utf-8'))
)

for message in consumer:
    print(f"Event: {message.value}")

Patterns

Dead Letter Queue (DLQ)

def process_with_retry(message, max_retries=3):
    retry_count = message.headers.get('x-retry-count', 0)

    try:
        process(message)
    except Exception as e:
        if retry_count < max_retries:
            # Republish with incremented retry count
            republish_with_delay(message, retry_count + 1)
        else:
            # Send to DLQ
            publish_to_dlq(message, str(e))

Troubleshooting

| Issue | Cause | Solution | |-------|-------|----------| | Message loss | No persistence | Enable durable queues | | Consumer lag | Slow processing | Scale consumers, batch processing | | Duplicate processing | No idempotency | Implement idempotent consumers |


Resources