moleculerjs/
:rocket: Progressive microservices framework for Node.js
USD raised
Recent activities
NATS is not working with moleculer-runner
Question | Is load balance per event/action or per service?
Moleculer project website down?
AMQP 1.0
Can I create a private or local service only that node could call it?
Can I connect with remote service written by other framework?
HAPI & Context & Tracing
NEXT: Subspan emit to jaeger fails
Regex Cache in Utils
preferLocal: false not force remote call
Type of this in hook
How to get text/xml request raw body using ApiGateway?
Middleware createService being invoked too early
What is the appropriate way to delete a key from the cacher?
help me about create an event listener
AMQP - autoDelete not working as expected
How to Populating one to many in mysql
Issue with services losing references to other dependencies
A way to destructure services into individual Docker images
Flexible logger configuration
TS - 0.14.0 - New possible contex param type of null is a breaking change
Is there a way to restart borker or service?
MemoryCacher Logic Errors
When using "Latency" strategy console warning "possible EventEmitter memory leak detected"
custom validator with fastest-validator throws error: TypeError: this.validator.init is not a function
custom error
Hot-Reload not working without Runner
v0.14 - ctx.meta being lost when calling this.actions
Runner closing automatically
[TypeScript] proxy class service methods through broker.createService
db adapter issue - can't perform textual search with "list"
Testing moleculer with jest wont allow you to use two awaits in events
Node created in expressjs can not see node created by Moleculer Runner
Default actions / sub actions
Moleculer Runner Daemon problem
NEXT: Jaeger don't trace remote actions
Broker does not start created services inside of the started service hook
Runner misconfiguration
A way to generate client code
Infinite Retry Loop
Kubernetes deployment in Docs?
Google Cloud Platform Deployment
Include Stacktrace in metrics with error information on metrics.trace.span.finish
Broken ES6 example in docs. parseServiceSchema doesn't start the service.
Breaking changes in version 0.14.0 and roadmap.
Documentation - v0.14
meta is not passed when using mcall
Don't swallow event exceptions
[Tracing] Default API service with jaeger tracing causes mem buff overflow
How to intercept transporter errors ?
0.14.0 beta - servicebroker instances not being reclaimed by GC due to tracing and metrics
moleculer-runner support for loading config file asynchronously
Add a benchmark to compare performance with `micro`
Tests of service is failed in case of service have dependencies.
0.14.0 beta - HotReload is not working since ServiceBroker doesn't destroy services properly.
Share $secureSettings with mixins
NATS server disconnecting randomly
Parameter validation for events (like actions)
Typescript type check error break hot reload
Declare plugins as peerDependencies
Kafka Transporter Stable release
"onError" hook in action schema
NodeID conflict on restart when nodeID is set and using Kafka transporter
Action TTL is overrided on second request by this.broker.cacher.get function.
Methods in mixins aren't used
requestID is null on first call, but has a value next
Dead AMQP queues left behind
suggestion on how to move from hemera-plugins
Can we add a middleware for particular alias?
[bug] Override Request Timeout
HTTP responses enhancements.
[TypeScript] Generic Context error
Typescript typings missing 'hooks' in ServiceSchema
Allow broker to watch for events
Allow customization of tracing span names
Detecting Events since last time service ran?
Service not found error
Unable to call broker on the same service in started lifecycle event
Drop bluebird
Redis client errors with batch commands (multi)
[discussion] Should all brokers respond to circuit breaker from one broker?
v0.14.0-rc1 TypeError: Cannot read property 'hooks' of undefined
start the services with nodejs
Nats trying to reconnect when a i call broker.stop
Console and Event metric reporters are handling snapshot interval incorrectly.
ENV deep configuration not working
Redis cluster as transporter
Configuration registry
Error: Cannot find module 'bluebird' | v0.14.0
[Typescript] ActionCacheOptions incorrect interface declaration
type based revive option to convert json data
How to use minxin with IntelliSense in vscode - typescript
Balanced events arrived twice.
Moleculerjs and moleculer-go compatibility issue
Process not shutting down if jaeger tracing is enabled
Active span not correctly set in dd-trace
Channel reconnect feature?
Isolation of bad requests
Hot reloading issue to detect new service files
Request is timed out when sending large files
Global error handler called multiple times
Heartbeats pollution problem
caller not set when calling and action
amqp disableBalancer = true => Reconnect not working
Need better understanding of the framework
'Orphan response is received' when using NATS balancer and stream params
moleculer config with sealed objects
Stream error when using 0.14.5
Cannot use custom logger config in typescript environment
Is there a way to access logger outside service?
[TypeScript] mcall type definition missing for Context
Question about shard strategy
Event Durability
Moleculer Datadog integration is not working
Separate Moleculer components from each other.
how to integrate Http client and server program in Moleculer?
QueueIsFullError when the project started
Cant discovery local services without external network Interfaces;
AMQP 1.0 transporter issue on CI server
[Question] Not An Issue - Just A Question
[lodash] Remove usage of _.isFunction
[lodash] Remove usage of _.isObject
[lodash] Remove usage of _.isString
[lodash] Remove usage of _.isPlainObject
[lodash] Remove usage of _.isArray
[lodash] Remove usage of _.isNaN
[lodash] Remove usage of _.assign
[lodash] Remove usage of _.isNumber
[lodash] Remove usage of _.random
[lodash] Remove usage of _.flatten
optimize HEARTBEAT performance
ActionParams type doesn't allow $$strict: 'remove' option
Detected a potential I/O issue on moleculer
INFO key for nodes cannot be found on registry after Redis restart
Create a large number of services dynamically, the services are lost after 10 minutes
using secure JSON parser
Stacktrace is not included in EventLegacy tracing
Error when connect Grafana to Prometheus in Moleculer
What is the best way to Poll SQS Messages
Allowing to set validator options in ServiceBroker options.
How can I call an external api from an action
HTTP based transporter for communication between microservices
Tracing flattenTags memory leak with api stream
Emit always event (configurable)
Add ability to add global action tracing tags
How we can horizontally scaled our services?
Change to drive letter casing causes Babel parse errors when babel-node is used with the runner
Can't setup winston as a logger
Event broadcast broken when using NATS balancing
Moleculer prints colored log messages when colored log messages are disabled
Trace spans should include the requestID as a tag to improve searchability
[question] how to create multipe nodes on only one service
param action change hard to understand
Cant pass model to other service , when returning this.model
Feat: moleculer-runner in cluster mode with settings instance by service
Hot Reload maximum call stack exceeded
Bug(registry): serialize a BigInt in settings
Issue with hot reload w/ moleculer-runner on node 14
Bug second level of mixins with $secureSettings
Maximum call stack size exceeded in Jaeger tracing
App run on dockers succesfully exits. Typescript
waitForServices should fail immediately if the broker is not started
hot-reload not working with moleculer runner in dev container
Inject custom tags dynamically in Datadog logger.
How to add cookie to response from actions
Unable to cache a value of null
How to read in authorisation header in the actions hooks
Validation for stream not working
Broker does not stop with multiples 'createService'
Error while run unit test on moleculer-cli generated project with es7 support
Error while running unit test of service async actions
Can't use events RegExp without '?' symbol
Event tracer sends tracing events about tracing events
Missing documentation on customLogger
Load Balancing on call to action on the same service.
Redis Transporter (Support for Redis Sentinel)
Using two different transporters
Plaintext TCP Transport nodes crash nodes with Encryption middleware
Get transporter from broker
Incorrect Avro schema for EVENT Packet causing service to crash
Miss-leading documentation for Custom Transporter and Serializer
Passing data to Service while loading it
Call service action of specyfic node by nodeID
Keep Moleculer error classes for calls between services
Cannot seem to get histogram metric on datadog
Use Deno instead of Nodejs
Redis cacher broker.cacher.clean error (Redis cluster)
Cron jobs with graceful exits are still being reported as Lost after 10 minutes due to heartbeats missing.
Service gets registered multiple times and is corrupting action ctx.params
Documentation site is down
Winston adapter is broken
Setting up infraestructure using moleculer and kubernetes (doubts)
Circular dependency loop possible hot-reload middleware
Incorrect cache keys generation for array params
Make Transporter prefix an option
Incorrect cache key generation for date objects
Deprecating schema-based serializers (ProtoBuf, Avro, Thrift)
How to send heartbeats when under heavy load and prevent service disconnection
Expose the Cacher middleware
Can't connect to NATS transporter: "client.on is not a function"
Apparently moleculer cannot write a log inside the docker container
Mixins with Typescript template & decorators way
Trace spans have inconsistent timing
[Transporter AMQP 0.9] Broker.transit undefined
List of service not working properly
Benchmarking score seems to be much less than the numbers given in the documentation.
ctx.meta is empty in events
Transporter NATS can not connect "client.on is not a function".
Abort or cancel a service action
Catching errors between nodes
Base tracer does not handle circular json objects as tags in action response
Utils type definitions not defined, preventing typescript import
Moleculer Runner ability to setting process title
Runner: passing initial custom data
moleculer init project failing with error
Cannot read property 'remove' of undefined
Misleading event architecure which violate separation of concerns
[Feature request] Declare location of `moleculer.config` via env vars
In the custom validation method has access to the broker or context
CBOR serializer not working with stream
distributed transaction?
Ease bundlers job
etcd3 and redis custom discoverers call serialize and deserialize incorrectly
makeBalancedSubscriptions is never invoked on the transporter when using Redis and etcd3 discoverers
Transit is not exported from the core module
Is Nat-Server, Docker and Heroku Deployment possible or there are other alternatives
read logger
etcd3 discoverer throws message serialization error on heartbeat
Additional log level
How it compares to NestJS?
Typescript: ThisType in ActionHandler is not work
0.14.14 in combination with nats 2.0.8 incorrectly handles "transporter": "nats://server:port" shortcut option
About formatter in moleculer
Version 0.14.14 - Metrics could not found: moleculer.request.error.total
NATS Transporter outputs ping message every 2 minutes
bug: defaultKeygen create same key with value undefined & "undefined" (string), null & "null"
Manageing inter communication
mcall typing seems to not follow the documentation
Middleware reordering
Duplicated MOL.RES.$nodeId topic in mqtt
Pino has deprecated bindings.level
Event handlers, destructuring & minifiers
Cacher should be ignored by the action handler if cacher is not connected
Example of object-mode-streaming in documentation
memory (and memoryLRU) Cacher cloning issue
Transit: messageHandler return type is inconsistent
Services is called twice when started
errorHandlerMiddleware prevents propagation of errors to the Transporter
Moleculer + Istio
How to disable default page
DELETE THIS ENTRY
How to catch db fail in moleculer js
A worker process has failed to exit gracefully and has been force exited. This is likely caused by tests leaking due to improper teardown. Try running with --detectOpenHandles to find leaks.
Customer Logger usage
persist a single payload which is targeted for multiple services
single JSON payload in Molecular API documenting
How to implemet swagger in Molecular
Add support to define services in ESM modules, or using ESM-only dependencies
Fetch data from multiple collection(mongodb) in single service
Establishing TCP Connections
allow action.cache.keys function access ctx
how to approach mutually exclusive dependencies
AMQP Communication - No response from the event you are listening
Broker.call waits forever if Redis transporter reconnects while transmitting a message
Call throws "options of undefined" when destructed from ctx
Export middleware order array to maintain consistency with internal middlewares ordering
Custom Load Balancing Strategy Does Not Take Effect
SQS Transporter
Error with command: npm i moleculer
Error with command : npm i moleculer
moleculer how to support swagger
Events when an error occured inside ServiceBroker
Error: Method must be a function
Can we support declaration merging for ServiceSchema, ActionSchema etc
[Action Hooks] Wildcards for subset of actions
why ctx.caller is not set when service call this.broker.call?
[FR] Export error types
Events signature issues
Authentication error with NATS
Getting BAD_PAYLOAD when starting broker with Jest
subscriber's event function ctx with different structure
Should we allow custom populate params?
Ctx is undefined when using shard strategy and preferLocal is false, throws error on emit
Dependencies deadlock in mixed architecture
Set requestID in internal logs
Some deeply nested options fed via docker compose env file are getting ignored
moleculer.services web site not working (SSL cert invalid)
Streaming does not work with enabled compression
Ignore undefined methods when extends from parent class Service<S = ServiceSettingSchema>
Disable cached response for an action
Possible error in broker.emit(). I cannot recognize that an event has been sent to the transport successfully.
ESM support breaks custom validator initialization
ctx meta user issues
Allow non-async function in service.started() and service.stopped()
errorHandler in moleculer.config.js
Configurable service dependencyTimeout in broker options
Monolithic dynamic service creation and destruction memory leak
Meta data is empty for stream with enabled compression
`waitForServices` times out after the first interval is reached since 0.14.22
0.14.22 Release Broke Service.mergeSchemas() and others
Tracing not working when set internalMiddlewares:false
Moleculer causes typescript errors with typescript version 4.8.2
Slower broker startup times since v0.14.20
mergeSchemas is no longer available as a static class method of Service
Why remove repl in .d.ts file? its not match document in website.
[issue] fixed to tests work correctly with @sinonjs/fake-timers in utils.spec.js
I have a problem sending data from frontend (ReactJs) to backend (NodeJs).
Error: Invalid 'undefined' type in validator schema.
Typescript definitions don't match the actual Javascript implementation
AMQP transporter issue
Question on how to use this framework
Actions visibility - possible security breach
Regression in master: Cannot read property '$secureSettings' of undefined
Cannot get nodeID in context
Move REPL to a separated optional module `moleculer-repl`
Reduce lib size
Protocol v2 changes
WebSockets Transport Layer
Fix datetime flaky test on serializers
moleculer-runner to support removing and adding services
There is no types file for importing as ESM module.
Getting **Parsing failed at** error while calling garphql mutation for upload image
Deprecation warning when declaring custom actions for internal services
RestSchema not allowed as array in `rest`
no clean exit on shutdown, with disableBalancer: true
Use of __proto__ seems discouraged
Hot reload is not working with this demo
Broker createService using es6 class not changing opts
Inconsistent behavior of 'emit'
Configurable auto logging for action in, out and error
[Proposal] broker.broadcast update and broker.send
call to an unavailable service should wait before throwing ServiceNotAvailable
Documentation on how-to-use-in-production
Event Sourcing support
Missing ctx on call middleware
Nats upgrade to jetstream
Registry with TCP transport in docker is working wrong
debounced localServiceChanged breaking with NATS
Circuit breaker not working
Enhance the moleculer ecosystem
Use broker Runner: Service name can't be empty
Feature Request - Complete TypeScript Implementation
Encryption error on GOSSIP packets
moleculer-amqp-queue issue
Performance issue with NATS transporter (v2.x.x)
Documentation on cache lock does not match the source
moleculer crash if ioredis can not change state to "ready"
Redis SSL URI not reconized as a Redis type discoverer
Installation fails for Node 20 LTS
API Load Testing results application crash | Apache Benchmark
How to deploy molecular to AWS lambda?
Default cache cleaner mixin not working
Bun runtime
using grunt.loadNpmTasks('grunt-contrib-obfuscator') cause service event context lost, always undefind
Mixin application order
Number key in cacher breaks when maxParamsLength is set and keys are specified
With NodeJS 22 : DeprecationWarning: The `punycode` module is deprecated
Is there a Java version of moleculer-channels?
Memory leak when a call to an action stream fails
New type for ServiceSchema breaks ServiceBroker.createService and interface Options
© 2019 BoostIO, Inc.