@nestjs/microservices
Version:
Nest - modern, fast, powerful node.js web framework (@microservices)
281 lines (280 loc) • 12.7 kB
JavaScript
"use strict";
Object.defineProperty(exports, "__esModule", { value: true });
exports.ClientRMQ = void 0;
/* eslint-disable @typescript-eslint/no-redundant-type-constituents */
const logger_service_1 = require("@nestjs/common/services/logger.service");
const load_package_util_1 = require("@nestjs/common/utils/load-package.util");
const random_string_generator_util_1 = require("@nestjs/common/utils/random-string-generator.util");
const shared_utils_1 = require("@nestjs/common/utils/shared.utils");
const events_1 = require("events");
const rxjs_1 = require("rxjs");
const operators_1 = require("rxjs/operators");
const constants_1 = require("../constants");
const rmq_record_serializer_1 = require("../serializers/rmq-record.serializer");
const client_proxy_1 = require("./client-proxy");
let rmqPackage = {}; // typeof import('amqp-connection-manager');
const REPLY_QUEUE = 'amq.rabbitmq.reply-to';
/**
* @publicApi
*/
class ClientRMQ extends client_proxy_1.ClientProxy {
constructor(options) {
super();
this.options = options;
this.logger = new logger_service_1.Logger(client_proxy_1.ClientProxy.name);
this.client = null;
this.channel = null;
this.pendingEventListeners = [];
this.isInitialConnect = true;
this.queue = this.getOptionsProp(this.options, 'queue', constants_1.RQM_DEFAULT_QUEUE);
this.queueOptions = this.getOptionsProp(this.options, 'queueOptions', constants_1.RQM_DEFAULT_QUEUE_OPTIONS);
this.replyQueue = this.getOptionsProp(this.options, 'replyQueue', REPLY_QUEUE);
this.noAssert =
this.getOptionsProp(this.options, 'noAssert') ??
this.queueOptions.noAssert ??
constants_1.RQM_DEFAULT_NO_ASSERT;
(0, load_package_util_1.loadPackage)('amqplib', ClientRMQ.name, () => require('amqplib'));
rmqPackage = (0, load_package_util_1.loadPackage)('amqp-connection-manager', ClientRMQ.name, () => require('amqp-connection-manager'));
this.initializeSerializer(options);
this.initializeDeserializer(options);
}
close() {
this.channel && this.channel.close();
this.client && this.client.close();
this.channel = null;
this.client = null;
this.pendingEventListeners = [];
}
connect() {
if (this.client) {
return this.connectionPromise;
}
this.client = this.createClient();
this.registerErrorListener(this.client);
this.registerDisconnectListener(this.client);
this.registerConnectListener(this.client);
this.pendingEventListeners.forEach(({ event, callback }) => this.client.on(event, callback));
this.pendingEventListeners = [];
this.responseEmitter = new events_1.EventEmitter();
this.responseEmitter.setMaxListeners(0);
const connect$ = this.connect$(this.client);
const withDisconnect$ = this.mergeDisconnectEvent(this.client, connect$).pipe((0, operators_1.switchMap)(() => this.createChannel()));
const withReconnect$ = (0, rxjs_1.fromEvent)(this.client, "connect" /* RmqEventsMap.CONNECT */).pipe((0, operators_1.skip)(1));
const source$ = (0, rxjs_1.merge)(withDisconnect$, withReconnect$);
this.connection$ = new rxjs_1.ReplaySubject(1);
source$.subscribe(this.connection$);
this.connectionPromise = this.convertConnectionToPromise();
return this.connectionPromise;
}
createChannel() {
return new Promise(resolve => {
this.channel = this.client.createChannel({
json: false,
setup: (channel) => this.setupChannel(channel, resolve),
});
});
}
createClient() {
const socketOptions = this.getOptionsProp(this.options, 'socketOptions');
const urls = this.getOptionsProp(this.options, 'urls') || [constants_1.RQM_DEFAULT_URL];
return rmqPackage.connect(urls, socketOptions);
}
mergeDisconnectEvent(instance, source$) {
const eventToError = (eventType) => (0, rxjs_1.fromEvent)(instance, eventType).pipe((0, operators_1.map)((err) => {
throw err;
}));
const disconnect$ = eventToError("disconnect" /* RmqEventsMap.DISCONNECT */);
const urls = this.getOptionsProp(this.options, 'urls', []);
const connectFailedEventKey = 'connectFailed';
const connectFailed$ = eventToError(connectFailedEventKey).pipe((0, operators_1.retryWhen)(e => e.pipe((0, operators_1.scan)((errorCount, error) => {
if (urls.indexOf(error.url) >= urls.length - 1) {
throw error;
}
return errorCount + 1;
}, 0))));
// If we ever decide to propagate all disconnect errors & re-emit them through
// the "connection" stream then comment out "first()" operator.
return (0, rxjs_1.merge)(source$, disconnect$, connectFailed$).pipe((0, operators_1.first)());
}
async convertConnectionToPromise() {
try {
return await (0, rxjs_1.firstValueFrom)(this.connection$);
}
catch (err) {
if (err instanceof rxjs_1.EmptyError) {
return;
}
throw err;
}
}
async setupChannel(channel, resolve) {
const prefetchCount = this.getOptionsProp(this.options, 'prefetchCount') ||
constants_1.RQM_DEFAULT_PREFETCH_COUNT;
const isGlobalPrefetchCount = this.getOptionsProp(this.options, 'isGlobalPrefetchCount') ||
constants_1.RQM_DEFAULT_IS_GLOBAL_PREFETCH_COUNT;
if (!this.noAssert) {
await channel.assertQueue(this.queue, this.queueOptions);
}
if (this.options.exchange && this.options.routingKey) {
await channel.bindQueue(this.queue, this.options.exchange, this.options.routingKey);
}
if (this.options.wildcards) {
const exchange = this.getOptionsProp(this.options, 'exchange', this.options.queue);
const exchangeType = this.getOptionsProp(this.options, 'exchangeType', 'topic');
await channel.assertExchange(exchange, exchangeType, {
durable: true,
});
}
await channel.prefetch(prefetchCount, isGlobalPrefetchCount);
await this.consumeChannel(channel);
resolve();
}
async consumeChannel(channel) {
const noAck = this.getOptionsProp(this.options, 'noAck', constants_1.RQM_DEFAULT_NOACK);
await channel.consume(this.replyQueue, (msg) => this.responseEmitter.emit(msg.properties.correlationId, msg), {
noAck,
});
}
registerErrorListener(client) {
client.addListener("error" /* RmqEventsMap.ERROR */, (err) => this.logger.error(err));
}
registerDisconnectListener(client) {
client.addListener("disconnect" /* RmqEventsMap.DISCONNECT */, (err) => {
this._status$.next("disconnected" /* RmqStatus.DISCONNECTED */);
if (!this.isInitialConnect) {
this.connectionPromise = Promise.reject('Error: Connection lost. Trying to reconnect...');
// Prevent unhandled promise rejection
this.connectionPromise.catch(() => { });
}
this.logger.error(constants_1.DISCONNECTED_RMQ_MESSAGE);
this.logger.error(err);
});
}
registerConnectListener(client) {
client.addListener("connect" /* RmqEventsMap.CONNECT */, () => {
this._status$.next("connected" /* RmqStatus.CONNECTED */);
this.logger.log('Successfully connected to RMQ broker');
if (this.isInitialConnect) {
this.isInitialConnect = false;
if (!this.channel) {
this.connectionPromise = this.createChannel();
}
}
else {
this.connectionPromise = Promise.resolve();
}
});
}
on(event, callback) {
if (this.client) {
this.client.addListener(event, callback);
}
else {
this.pendingEventListeners.push({ event, callback });
}
}
unwrap() {
if (!this.client) {
throw new Error('Not initialized. Please call the "connect" method first.');
}
return this.client;
}
async handleMessage(packet, options, callback) {
if ((0, shared_utils_1.isFunction)(options)) {
callback = options;
options = undefined;
}
const { err, response, isDisposed } = await this.deserializer.deserialize(packet, options);
if (isDisposed || err) {
callback?.({
err,
response,
isDisposed: true,
});
}
callback?.({
err,
response,
});
}
publish(message, callback) {
try {
const correlationId = (0, random_string_generator_util_1.randomStringGenerator)();
const listener = ({ content, options, }) => this.handleMessage(this.parseMessageContent(content), options, callback);
Object.assign(message, { id: correlationId });
const serializedPacket = this.serializer.serialize(message);
const options = serializedPacket.options;
delete serializedPacket.options;
this.responseEmitter.on(correlationId, listener);
const content = Buffer.from(JSON.stringify(serializedPacket));
const sendOptions = {
replyTo: this.replyQueue,
persistent: this.getOptionsProp(this.options, 'persistent', constants_1.RQM_DEFAULT_PERSISTENT),
...options,
headers: this.mergeHeaders(options?.headers),
correlationId,
};
if (this.options.wildcards) {
const stringifiedPattern = (0, shared_utils_1.isString)(message.pattern)
? message.pattern
: JSON.stringify(message.pattern);
// The exchange is the same as the queue when wildcards are enabled
// and the exchange is not explicitly set
const exchange = this.getOptionsProp(this.options, 'exchange', this.queue);
this.channel.publish(exchange, stringifiedPattern, content, sendOptions).catch(err => callback({ err }));
}
else {
this.channel.sendToQueue(this.queue, content, sendOptions).catch(err => callback({ err }));
}
return () => this.responseEmitter.removeListener(correlationId, listener);
}
catch (err) {
callback({ err });
return () => { };
}
}
dispatchEvent(packet) {
const serializedPacket = this.serializer.serialize(packet);
const options = serializedPacket.options;
delete serializedPacket.options;
return new Promise((resolve, reject) => {
const content = Buffer.from(JSON.stringify(serializedPacket));
const sendOptions = {
persistent: this.getOptionsProp(this.options, 'persistent', constants_1.RQM_DEFAULT_PERSISTENT),
...options,
headers: this.mergeHeaders(options?.headers),
};
const errorCallback = (err) => err ? reject(err) : resolve();
return this.options.wildcards
? this.channel.publish(
// The exchange is the same as the queue when wildcards are enabled
// and the exchange is not explicitly set
this.getOptionsProp(this.options, 'exchange', this.queue), (0, shared_utils_1.isString)(packet.pattern)
? packet.pattern
: JSON.stringify(packet.pattern), content, sendOptions, errorCallback)
: this.channel.sendToQueue(this.queue, content, sendOptions, errorCallback);
});
}
initializeSerializer(options) {
this.serializer = options?.serializer ?? new rmq_record_serializer_1.RmqRecordSerializer();
}
mergeHeaders(requestHeaders) {
if (!requestHeaders && !this.options?.headers) {
return undefined;
}
return {
...this.options?.headers,
...requestHeaders,
};
}
parseMessageContent(content) {
const rawContent = content.toString();
try {
return JSON.parse(rawContent);
}
catch {
return rawContent;
}
}
}
exports.ClientRMQ = ClientRMQ;