Ecosyste.ms: Awesome

An open API service indexing awesome lists of open source software.

Awesome Lists | Featured Topics | Projects

Publish-subscribe pattern

The publish-subscribe pattern (short: pubsub) is an event handling and messaging pattern where the consumer subscribes to the provider, which in return can then publish a message that can be picked up and processed by each subscribed consumer.

https://github.com/mchmarny/app-portability-using-dapr

Demo repo showcasing ease of porting apps and their dependencies across different compute environments

aci azure containers dapr docker kubernetes portability pubsub state

Last synced: 31 Dec 2024

https://github.com/gunerkaanalkim/pubs

a message broker that applied publisher/subscriber pattern with Typescript

message-broker publisher-subscriber pubsub typescript

Last synced: 01 Jan 2025

https://github.com/damiancipolat/redis_pubsub_node

A complete example of event sourcing using redis pub/sub features with docker and nodejs + Typescript. In this situation we will create a SMS send distributed service.

docker nodejs pubsub redis typescript

Last synced: 28 Dec 2024

https://github.com/knownasilya/ember-cli-deploy-gcloud-pubsub

Notify that a deployment has been activated via Google PubSub.

ember ember-addon ember-cli-deploy-plugin google-cloud pubsub

Last synced: 08 Jan 2025

https://github.com/antonioalmeida/pony-pubsub

Implementation of progressive Publish-Subscribe scenarios in Pony as a means to document an adaptation to the Actor Model paradigm.

actor-model hacktoberfest parallel patterns pony pubsub

Last synced: 21 Jan 2025

https://github.com/vyzo/gerbil-netvis

A simple network visualizer for pubsub message propagation

gerbil ipfs pubsub

Last synced: 04 Jan 2025

https://github.com/rtakland/kwsify

基于websocket的实时sub/pub服务

pubsub realtime server websocket

Last synced: 25 Nov 2024

https://github.com/femtotrader/pubsub.jl

A very basic Julia implementation of pub-sub pattern

design-patterns julia pubsub

Last synced: 18 Dec 2024

https://github.com/adamluzsi/googlecloudpubsub

Golang Pubsub pipeline consumer for rapid develeopment and testing when building google pubsub pipeline enhancers

bdd cloud gcloud-pubsub golang google pubsub tdd

Last synced: 18 Dec 2024

https://github.com/twpayne/go-pubsub

Package pubsub is a simple publish-subscribe implementation using generics.

go golang publish-subscribe pubsub

Last synced: 13 Oct 2024

https://github.com/hisorange/circuit

Versatile Messaging library written in Typescript.

messaging pubsub redis rpc typescript

Last synced: 14 Oct 2024

https://github.com/dbut2/slackgpt

AI Slack chat bot using models from OpenAI

ai bot chatbot cloud-functions gcp go openai pubsub slack slack-bot

Last synced: 25 Dec 2024

https://github.com/elithrar/pubsub-example-worker

An example Worker that acts as an on-publish hook for Pub/Sub (https://developers.cloudflare.com/pub-sub/).

cloudflare mqtt pubsub typescript workers

Last synced: 24 Nov 2024

https://github.com/premiering/wubsub

A tiny ws:// RPC server using a JSON protocol.

go ipc melody pubsub rpc websocket

Last synced: 02 Jan 2025

https://github.com/jrouaix/mutopic

Micro topic pubsub

message-broker pubsub reactive rx topic

Last synced: 11 Jan 2025

https://github.com/mizrael/asyncservices

Sample repository showing how to handle requests asynchronously.

aspnet-core dotnet-core mongodb pubsub rabbitmq tutorial web-api

Last synced: 28 Nov 2024

https://github.com/araucaris/hermes

Hermes is a messaging framework, offering publish-subscribe, asynchronous request-response, key-value storage access and distributed locking.

jackson messaging msgpack nats nats-messaging pubsub pubsub-subscriber redis redis-messaging

Last synced: 10 Nov 2024

https://github.com/ericlondon/ruby-redis-pub-sub-worker-queue

Ruby Redis Pub/Sub Worker Queue

pubsub queue redis ruby worker

Last synced: 12 Nov 2024

https://github.com/unlight/onn

Event emitter using DOM's addEventListener/dispatchEvent

bus emit-events emitter event-emitter eventbus events pubsub

Last synced: 27 Dec 2024

https://github.com/hc-oss/react-gbus

global event bus hook for react (pub/sub)

broadcast emit eventemitter events pubsub react subscribe

Last synced: 01 Dec 2024

https://github.com/pot-pourri/pubsub

:mailbox_with_mail: Publish-subscribe data structures for JavaScript

javascript js publish pubsub subscribe

Last synced: 22 Dec 2024

https://github.com/lwahlmeier/pse

The Java pubsub emulator sucks

emulater gcp golang pubsub queue

Last synced: 30 Nov 2024

https://github.com/diagrid-labs/dapr-workshop

This repository contains a set of hands-on challenges designed to introduce you to Dapr's most popular APIs and give you a starting point to build your own distributed applications.

api cloudnative dapr pubsub state-management

Last synced: 19 Jan 2025

https://github.com/roadrunner-server/google-pub-sub

Google PubSub Jobs driver

driver google jobs pubsub

Last synced: 06 Nov 2024

https://github.com/restuwahyu13/express-todo-redis

todo app example express.js with redis custom pub/sub implementation

expressjs nodejs pubsub redis todoapp

Last synced: 03 Jan 2025

https://github.com/wmantly/p2psub

Mesh peer to peer JSON Pub/Sub with no extremal dependencies.

json mesh nodejs p2p pubsub

Last synced: 21 Dec 2024

https://github.com/bruno-garcia/messaging

Library for simple pub/sub with different serialization and brokers

dotnet-core json kafka messaging-library protobuf pubsub redis

Last synced: 18 Jan 2025

https://github.com/inhedron/mqtt-repeater

The repeater tool of the messages that you have chosen from a mqtt broker to another mqtt broker

mqtt pubsub repeater

Last synced: 30 Nov 2024

https://github.com/soulgarden/rmq-pubsub

Rmq simple publisher and subscriber with circuit breaker and graceful shutdown support

go library publisher pubsub pubsub-library rabbitmq subscriber

Last synced: 03 Dec 2024

https://github.com/ianwalter/subpub

A super-simple JavaScript Subscribe/Publish (pubsub) implementation

events pattern-matching pubsub

Last synced: 20 Dec 2024

https://github.com/mchmarny/tweet-provider

Cloud Run Twitter search service, configured with service account identity, invoked by Cloud Scheduler, and persisting query state across invocations in Firestore. This service also publishes search results to Cloud PubSub for further consumption downstream, and records its tweet throughput as custom metrics in Stackdriver.

cloudrun firestore metrics pubsub scheduler stackdriver twitter

Last synced: 08 Nov 2024

https://github.com/evrythng/evrythng-pubsub.js

Plugin for evrythng.js that adds PubSub connectivity with MQTT and MQTT over WebSockets.

evrythng internetofthings iot mqtt pubsub websockets

Last synced: 21 Nov 2024

https://github.com/botchris/go-pubsub

multi-topic pub/sub package for Go with pluggable providers and statically typed.

aws go golang kubemq pubsub sns sqs

Last synced: 03 Dec 2024

https://github.com/mluby/grapevine

Peer-to-peer pub-sub

library p2p peer-to-peer pubsub webrtc

Last synced: 28 Dec 2024

https://github.com/jomaxso/segres

A mediator library for .Net using strongly-typed handler implementations. It provides a synchronise and asynchronise api, which is optimized for speed and memory.

asp-net-core aspnet-web-api aspnetcore dotnet dotnet-core dotnet7 mediation minimal-api net7 pubsub sender-reciever

Last synced: 03 Dec 2024

https://github.com/kiko-g/feup-sdle

FEUP SDLE | Large Scale Distributed Systems | 2021/22

decentralized distributed-systems pubsub

Last synced: 23 Nov 2024

https://github.com/aratan/tensorflow_raspberry

install tensorflow in raspberry pi3

ipfs pubsub python raspberry-pi tensorflow

Last synced: 20 Jan 2025

https://github.com/kareem-emad/switch

Event Management Service allowing you to register subscribers/topics. The service is based on publisher/subscriber model.

events pubsub

Last synced: 19 Jan 2025

https://github.com/kiko-g/reliable-pub-sub-service

FEUP SDLE | Reliable Pub/Sub Service | 2021/22

pubsub python zeromq

Last synced: 23 Nov 2024

https://github.com/kevinhillinger/openhack-serverless

Serverless implementation in TypeScript using Azure Functions to handle HTTP, Pub/Sub topic, and Saga to handle microservice interactions and data ingestion using event driven patterns

azure-functions-v3 durable-functions event-driven pubsub saga-pattern serverless typescript

Last synced: 07 Dec 2024

https://github.com/softwareag/j2ee_messaging_apps

Modular J2EE messaging applications that rely on common JCA Resource Adapters to interact with Messaging provider such as SoftwareAG Universal Messaging

j2ee java jca jms jms-broker jms-queue pubsub universal-messaging webmethods

Last synced: 20 Dec 2024

https://github.com/belajarqywok/discord_alerting_system

Alerting System connected to Discord (via webhook) by implementing Event-Driven Architecture (EDA).

alerting-system cloud-functions cloud-monitoring event-driven pubsub stackdriver

Last synced: 30 Nov 2024

https://github.com/foxysolutions/LWC-Style-Distributor

Style Distributor Component for Salesforce, where Sibling Event Structures are applied (PubSub and Lightning Messaging Service).

css-variables events lightning-messaging-service lightning-web-components lwc pubsub salesforce style-distributor

Last synced: 03 Nov 2024

https://github.com/krisharul26/iot-based-remote-sensor-data-monitoring-and-actuator-control

As the current housing systems are moving towards automation, the focus on the systems used within the house is given more focus than the customer requirement. The systems available in the current market are complex and expensive. The objective of the “IoT based remote sensor data monitoring and actuator control” project is to create a partial open-source monitoring system that can be customized based on the individual requirements of the customer which is cheaper than the available market alternatives and user-friendly.

dht11 grafana-dashboard influxdb iot mqtt pubsub raspberry-pi-3 raspberry-pi-zero-w ultrasonic-sensor waterlevelcontroller

Last synced: 04 Jan 2025

https://github.com/shahaf-f-s/socketsio

A python wrapper around socket for generalized communication protocols, unified socket interface, utility methods, and modular protocol swapping capeabilities. Including a socket based Pub/Sub system.

pubsub socket socket-io socket-programming

Last synced: 19 Dec 2024

https://github.com/alexgalhardo/learning-message-queue-and-pub-sub

Simple project I created with references and examples to learn about message queues and publisher/subscriber pattern with different technologies.

aws-dynamodb aws-s3 aws-sns aws-sqs bullmq docker docker-compose localstack pubsub rabbitmq redis typescript

Last synced: 08 Jan 2025

https://github.com/jharrilim/multiplex

Key-Value store with subscriptions

key pubsub rust store value

Last synced: 31 Dec 2024

https://github.com/chandanpasunoori/event-sync

Event Sync is for syncing events from multiple sources to multiple destinations, targetted for adhoc events, where sources support acknowledgement functionality.

bigquery golang-tools google-cloud-platform pubsub

Last synced: 19 Dec 2024

https://github.com/puskar-roy/scaleable-chat-app

Scaleable Chat App Using Typescript, Node.js, Express Js, Socket.IO, Redis, Pub/sub

expressjs nextjs14 nodejs pubsub redis socket-io typescript

Last synced: 16 Jan 2025

https://github.com/ackeecz/terraform-gcp-dataflow_pubsub_to_bq

Dataflow job subscriber to PubSub subscription. It takes message from subscription and push it into BigQuery table.

bigquery dataflow pubsub terraform-module

Last synced: 07 Jan 2025

https://github.com/infumia/pubsub

Simplified pubsub library for Redis and various databases.

jackson java kotlin pubsub redis

Last synced: 21 Dec 2024

https://github.com/abhisekp/jest-pub-sub

Test Redis PubSub using Jest testing framework

demo jest pubsub redis testing

Last synced: 21 Dec 2024

https://github.com/stevenferrer/kafka-pubsub

kafka pub-sub demo

go go-kit golang kafka pubsub

Last synced: 25 Dec 2024

https://github.com/plvo/redis-pubsub

A Rust script that uses Redis to test the one-to-many Pub/Sub mechanism.

pubsub redis rust

Last synced: 12 Jan 2025

https://github.com/magnuschase03/pubsubgo

This is a simple pub/sub service written in Go.

go pubsub

Last synced: 20 Dec 2024

https://github.com/trailsjs/trailpack-pubsub

Redis Pub/Sub implementation for Trails.js app

pubsub trailpack trails

Last synced: 02 Jan 2025

https://github.com/jgantunes/pulsarcast-test-harness

A test harness for Pulsarcast using ipfs-testbed

decentralized ipfs-testbed p2p pubsub pulsarcast test-harness

Last synced: 26 Dec 2024

https://github.com/prezha/pubsubctl

pubsubctl is a basic Google Cloud Platform Pub/Sub [Emulator] CLI

gcloud gcloud-pubsub gcloud-sdk google-cloud-pubsub pubsub pubsub-emulator pubsubclient

Last synced: 16 Dec 2024

https://github.com/woorui/aws-msg

AWS SQS Pub/Sub Primitives implemented by aws-sdk-go-v2

aws aws-sdk go-msg pubsub sqs sqs-queue

Last synced: 11 Jan 2025

https://github.com/dozyio/gossipsub-simulator

Gossipsub Simulator

gossipsub libp2p pubsub

Last synced: 26 Dec 2024

https://github.com/beatthat/notifications

Global system for pub/sub notification events by string 'type'.

loosely-coupled-design message-api messaging notifications observer observer-pattern pubsub unity3d

Last synced: 26 Dec 2024

https://github.com/kelindar/metering

This metering plugin for emitter.io broker persists usage in Google Datastore.

datastore emitter-io plugin pubsub

Last synced: 02 Jan 2025

https://github.com/siddhi-io/siddhi-io-googlepubsub

Extension that allows communicating with topics located in Google Pub-Sub

extension google-cloud google-pubsub io message-queue pubsub siddhi

Last synced: 08 Nov 2024

https://github.com/cristianoliveira/ifrone

A tiny wrapper around cross-window communication.

iframe iframe-communication iframe-pubsub lightweight pubsub wrapper

Last synced: 17 Jan 2025

https://github.com/smikhalevski/event-bus

🚌 Yet another event bus. There are many like it, but this one is mine.

event-bus pubsub reactive rx

Last synced: 09 Jan 2025

https://github.com/backendstack21/realtime-pubsub-client-python

The official Realtime Pub/Sub client for Python

client gateway messaging pubsub python realtime websocket

Last synced: 09 Nov 2024

https://github.com/cdaringe/pg-subscribe

subscribe to postgres events in node via LISTEN/NOTIFY apis

events listen notify postgres postgresql pubsub typescript

Last synced: 11 Nov 2024

https://github.com/mushoffa/redis-pubsub-go

Demo application and code example for Redis Pub/Sub using Go language

docker go golang pubsub redis

Last synced: 15 Jan 2025

https://github.com/qddegtya/isomorphic-channel

📞 Isomorphic channel for Micro Frontends

iframe-communicator microfrontends pubsub

Last synced: 12 Jan 2025

https://github.com/castor-labs/queue

A simple queue abstraction for your PHP projects

composer-library consumer php php7 producer pubsub queue

Last synced: 12 Jan 2025

https://github.com/sokil/pubsub-server

Publish/Subscribe server in Golang which broadcast messages to all other connected clients

chat go golang pubsub

Last synced: 09 Dec 2024

https://github.com/amitrajitdas/googlecloudready-facilitator-program

Challenge Lab solutions for GoogleCloudReady Facilitator Program

bucket cloud docker gcloud google kubernetes pubsub stackdriver

Last synced: 27 Dec 2024

https://github.com/psaia/fast-observer

A blazingly fast asynchronous O(1)-capable event dispatcher.

event-dispatcher observer pubsub typescript

Last synced: 02 Nov 2024

https://github.com/tahmid-saj/notification-service

Pub/Sub based notification service API for sending email and mobile push notifications. Developed using Go / Gin, AWS SES, SNS, S3.

aws-s3 aws-ses aws-sns gin go notifications pubsub

Last synced: 09 Dec 2024

https://github.com/moonshrd/p2chat-android

Port of p2chat to Android

android iot libp2p mesh pubsub

Last synced: 26 Nov 2024

https://github.com/roitinnovation/roit-queues

Queue manager for Typescript, as well as Nestjs.

cloudtasks nestjs nodejs pubsub queue typescript

Last synced: 09 Nov 2024

https://github.com/drumath2237/pubsub-android-test

UnityでAzure Web PubSubによる双方向通信を使用するデモ

azure csharp nuget pubsub unity

Last synced: 15 Jan 2025

https://github.com/rajat23/postgres-redis-connector

Connector which will replicate data from PostgreSql to Redis compatible structure using PostgreSql's PubSub(NOTIFY-LISTEN) paradigm

connector postgresql pubsub redis

Last synced: 03 Jan 2025

https://github.com/noyzys/nautchkafe-rabbit-bridge

Lightweight, flexible, and functional message-passing pubsub system built with RabbitMQ

broker fp functional-programming java message-broker message-queue pubsub rabbit rabbitmq rabbitmq-client vavr

Last synced: 29 Dec 2024

https://github.com/YannickFricke/TwubSub

Elixir Twitch PubSub bindings

elixir pubsub twitch

Last synced: 31 Oct 2024

https://github.com/tdjsnelling/dwsps

Tiny distributed websocket pub/sub system

distributed javascript pubsub websocket

Last synced: 15 Dec 2024

https://github.com/AdrienMazet/fri-go

TP Infrastructures d'intégration

go http mqtt pubsub redis rest

Last synced: 14 Nov 2024

https://github.com/ackeecz/terraform-gcp-pubsub

Terraform module for GCP PubSub resources

gcp pubsub terraform-module

Last synced: 10 Nov 2024

https://github.com/xiscodev/store-and-pubsub

A simple library to manage a Store and subscriptions to store values

browser javascript-library pubsub store

Last synced: 16 Jan 2025

https://github.com/nodefluent/roach-storm

Apache Kafka <=:fireworks:=> Google Pub/Sub

apache api bridge cloud controlled flow google kafka pubsub

Last synced: 08 Jan 2025

https://github.com/artyom/wspush

Service to deliver redis PUBSUB messages over websocket

pubsub websocket

Last synced: 14 Nov 2024

https://github.com/cluster-labs/cosmos

A decentralized communication stack

crdt ipfs libp2p pubsub

Last synced: 17 Jan 2025

https://github.com/questnetwork/quest-pubsub-js

JavaScript implementation of the Quest Network Second Layer PubSub Protocol

decentralized ecdsa end-to-end-encryption ipfs nodejs pubsub

Last synced: 20 Jan 2025

https://github.com/dataphos/schema-registry

Schema Registry is a product used for schema management and message validation.

cloud-native data-mesh data-stream event-driven go kafka messaging pubsub schema-registry serverless servicebus

Last synced: 15 Dec 2024

Publish-subscribe pattern Awesome Lists
Publish-subscribe pattern Categories