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/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/hexcowboy/stetson

A pure rust pubsub server

publish-subscribe pubsub rust server websockets

Last synced: 15 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/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: 19 Nov 2024

https://github.com/lwahlmeier/pse

The Java pubsub emulator sucks

emulater gcp golang pubsub queue

Last synced: 30 Nov 2024

https://github.com/dpwgc/imc-message-center

通讯中台-消息推送中心(DDD领域驱动设计+CQRS架构实战项目)

b broadcast cqrs ddd mariadb pubsub redis spring-boot websocket

Last synced: 19 Nov 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/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/kareem-emad/switch

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

events pubsub

Last synced: 18 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/bruno-garcia/messaging

Library for simple pub/sub with different serialization and brokers

dotnet-core json kafka messaging-library protobuf pubsub redis

Last synced: 20 Dec 2024

https://github.com/computnik/es6-pub-sub

Minimalistic Pub-Sub library in ES6

babel-es6 es6 gulp javascript pubsub

Last synced: 23 Nov 2024

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/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/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/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/zafar-saleem/react-event-architecture

This is a sample repository for my article on medium with the title [Event Base Architecture Using React](https://betterprogramming.pub/event-base-architecture-using-react-c0600d29d5ae). Simply clone the repo and run it as mentioned in `package.json` file.

architecture articles better-programming blog design-patterns medium-article pubsub react reactjs

Last synced: 08 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/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/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/nhatthaiquang-agilityio/dapr-publish-subscribe

Example: Distributed Application Runtime(DAPR) Publish and Subscriber messages via RabbitMQ and Azure Service Bus

azure-service-bus container-app dapr dapr-component dapr-pub-sub github-actions messaging microservices net7 pubsub rabbitmq

Last synced: 23 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: 08 Nov 2024

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/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: 08 Nov 2024

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

A simple network visualizer for pubsub message propagation

gerbil ipfs pubsub

Last synced: 17 Dec 2024

https://github.com/mchmarny/kpush

Demo of signed message push from PubSub to Knative service

gcp golang knative pubsub security

Last synced: 08 Nov 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/mchmarny/stockersrc

Twitter data source container executing in GCE VM

container gce pubsub twitter

Last synced: 08 Nov 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/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/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/pouchlabs/pouchrealtor

blazing fast socket.io alternative,pure websockets.

io pubsub realtime socket websocket ws

Last synced: 14 Nov 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/drumath2237/pubsub-android-test

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

azure csharp nuget pubsub unity

Last synced: 15 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/yongwangd/rx-event

A very simple but powerful event pub/sub package with only 6 lines of source code.

eventemitter eventemitter4 javascript node nodejs pubsub rxjs

Last synced: 24 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 Nov 2024

https://github.com/cristianoliveira/ifrone

A tiny wrapper around cross-window communication.

iframe iframe-communication iframe-pubsub lightweight pubsub wrapper

Last synced: 16 Nov 2024

https://github.com/aamiralam/push-notification-service

A firebase cloud function to send push notifications to all clients subscribed to a topic

express firebase-functions nodejs pubsub

Last synced: 24 Nov 2024

https://github.com/batux/ng-event-bus

ng-event-bus

angularjs eventbus pubsub

Last synced: 17 Nov 2024

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

A decentralized communication stack

crdt ipfs libp2p pubsub

Last synced: 17 Nov 2024

https://github.com/mjancarik/esmj-emitter

Lightweight emitter with zero dependencies for sync/async operation with from listeners result

browser eventemitter events javascript nodejs pubsub

Last synced: 17 Oct 2024

https://github.com/yss14/node-redis-eventbus

A simple event bus powered by node-redis to communicate between multiple node instances

eventbus eventbus-library events node-redis nodejs pubsub redis

Last synced: 17 Nov 2024

https://github.com/cbuschka/gcp-examples

Example solutions with Terraform and Java on GCP

gcp gcs java pubsub terraform

Last synced: 15 Nov 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: 06 Dec 2024

https://github.com/ragmaanir/besked

Small typed PubSub library for crystal.

crystal pubsub

Last synced: 14 Nov 2024

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

https://github.com/rob-blackbourn/jetblack-messagebus

A real time message bus written in C# on dotnet 6.0

messagebus messaging pubsub

Last synced: 19 Dec 2024

https://github.com/node-casbin/pubsub-watcher

Google Cloud Pub/Sub watcher for Node-Casbin

abac acl auth authorization authz casbin gcp google-cloud middleware pubsub rbac watcher

Last synced: 20 Nov 2024

https://github.com/manesioz/rilly

Distributed change data capture (CDC) framework for Google BigQuery

change-data-capture distributed-systems google-bigquery kafka pubsub python3

Last synced: 17 Nov 2024

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: 11 Nov 2024

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/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/YannickFricke/TwubSub

Elixir Twitch PubSub bindings

elixir pubsub twitch

Last synced: 31 Oct 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: 12 Nov 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: 11 Nov 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/nodefluent/roach-storm

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

apache api bridge cloud controlled flow google kafka pubsub

Last synced: 11 Nov 2024

https://github.com/jepozdemir/event-publisher

Basic event publish/subscribe implementation that transfers a message from a sender to a receiver. It provides a loosely coupled communication between objects.

csharp dotnet dotnetcore eventbus eventhandling events publish-subscribe pubsub realtime

Last synced: 18 Nov 2024

https://github.com/maximoleinyk/pubsub-filter

GKE Replacement for PubSub-to-PubSub Cloud Dataflows in GCP

cli cloud-dataflow docker gcp gke ipc kubernetes node-ipc nodejs pubsub typescript

Last synced: 10 Nov 2024

https://github.com/olivere/nats-streaming-server-example

An example of using a local NATS Streaming Server cluster for pub/sub.

golang-examples nats nats-streaming-server pubsub

Last synced: 19 Nov 2024

https://github.com/cuongndc9/pubsub_go

a simple 💅 pusub using go

103cuong go golang pubsub

Last synced: 21 Nov 2024

https://github.com/benmeehan/goscribe

A fast, simple, pure golang pub-sub broker.

broker golang pubsub

Last synced: 01 Dec 2024

https://github.com/khadkarajesh/iot-tutorial

Projects consist the necessary code to interact with the google iot cloud platform by iot devices

google-iot google-iot-core iot mqtt pubsub python3 raspberry-pi

Last synced: 13 Nov 2024

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: 10 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/dahlia/narabi

A simple Pythonic asynchronous interface to inter-process pub/sub

pub-sub pubsub

Last synced: 20 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/banyc/simple-messaging

Brokerless messaging. Pub/Sub. Producer/Consumer. Best effort. Pure Go. No C. No CGO. NO libwhatsoever.

best-effort brokerless messaging producer-consumer pubsub

Last synced: 19 Nov 2024

https://github.com/denniszielke/aca-dapr-simple-messaging

Simple demo app for demonstrating dapr pubsub in Azure Container Apps

azure container-apps dapr pubsub

Last synced: 24 Dec 2024

https://github.com/betterwrite/vue-pubsub

A Pubsub Plugin (or better Event Bus) for Vue.

event-bus mitt pubsub typescript vue vue3 vuejs

Last synced: 22 Nov 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/magnuschase03/pubsubgo

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

go pubsub

Last synced: 20 Dec 2024

https://github.com/tdjsnelling/dwsps

Tiny distributed websocket pub/sub system

distributed javascript pubsub websocket

Last synced: 15 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/xiscodev/store-and-pubsub

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

browser javascript-library pubsub store

Last synced: 16 Nov 2024

https://github.com/redding/qs

Handler-based message queueing (jobs) and pub/sub (events).

message-queue pubsub ruby

Last synced: 05 Nov 2024

https://github.com/piotrpersona/goq

Golang interprocess, in-memory pub-sub message queue.

go go-generics golang golang-library goroutines pubsub queue

Last synced: 10 Nov 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/infumia/pubsub

Simplified pubsub library for Redis and various databases.

jackson java kotlin pubsub redis

Last synced: 21 Dec 2024

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/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/d-exclaimation/subpub

A lightweight Akka stream PubSub engine for distributing data to multiple consumers.

akka-actors akka-streams pubsub real-time scala topic-modeling

Last synced: 07 Nov 2024

https://github.com/tutv/coney

Simple pub/sub and queue with Rabbitmq

npm pubsub queue rabbitmq

Last synced: 10 Dec 2024

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

Publish-subscribe pattern Awesome Lists
Publish-subscribe pattern Categories