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/rtakland/kwsify

基于websocket的实时sub/pub服务

pubsub realtime server websocket

Last synced: 25 Nov 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/vyzo/gerbil-netvis

A simple network visualizer for pubsub message propagation

gerbil ipfs pubsub

Last synced: 04 Jan 2025

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/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/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/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/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/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/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: 06 Dec 2024

https://github.com/jrouaix/mutopic

Micro topic pubsub

message-broker pubsub reactive rx topic

Last synced: 12 Nov 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/aratan/tensorflow_raspberry

install tensorflow in raspberry pi3

ipfs pubsub python raspberry-pi tensorflow

Last synced: 19 Nov 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/salaah01/py-pub-sub

A simple pub-sub implementation in Python.

devops pubsub python python3 server

Last synced: 06 Jan 2025

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

A pure rust pubsub server

publish-subscribe pubsub rust server websockets

Last synced: 15 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/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/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/mluby/grapevine

Peer-to-peer pub-sub

library p2p peer-to-peer pubsub webrtc

Last synced: 28 Dec 2024

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/roadrunner-server/google-pub-sub

Google PubSub Jobs driver

driver google jobs pubsub

Last synced: 06 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/lwahlmeier/pse

The Java pubsub emulator sucks

emulater gcp golang pubsub queue

Last synced: 30 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/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/ianwalter/subpub

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

events pattern-matching pubsub

Last synced: 20 Dec 2024

https://github.com/johngeorgewright/hot-press

Event lifecycle management in JavaScript

event-hierarchy event-lifecycle pubsub

Last synced: 21 Dec 2024

https://github.com/574n13y/google-pub-subtopic

Develop Terraform code for creating and managing Google Pub/Subtopic.

gcp pubsub pubsub-subscriber terraform terraform-module terraform-provider terraform-workspace topic

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/platdesign/cana

rx-pubsub

nodejs pubsub rx ws

Last synced: 19 Dec 2024

https://github.com/sumory/mas

a state management library.

actions pubsub redux state-management

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

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

azure csharp nuget pubsub unity

Last synced: 15 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/abhisekp/jest-pub-sub

Test Redis PubSub using Jest testing framework

demo jest pubsub redis testing

Last synced: 21 Dec 2024

https://github.com/knownasilya/index-html-loader

Load and cache index.html using GCP PubSub, works great with ember-cli-deploy

deployment ember-cli-deploy pubsub

Last synced: 16 Oct 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/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/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/magnuschase03/pubsubgo

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

go pubsub

Last synced: 20 Dec 2024

https://github.com/atomstatehq/atomstate

Atomstate is an open-source messaging system designed for modern distributed applications, particularly in cloud-native environments

atomstate cloud cloud-computing cloud-native distributed distributed-systems event-streaming message-bus messaging microservices pubsub queuing

Last synced: 30 Nov 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: 29 Dec 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/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/redding/qs

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

message-queue pubsub ruby

Last synced: 05 Nov 2024

https://github.com/tdjsnelling/dwsps

Tiny distributed websocket pub/sub system

distributed javascript pubsub websocket

Last synced: 15 Dec 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/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/dahlia/narabi

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

pub-sub pubsub

Last synced: 05 Jan 2025

https://github.com/autom8ter/queuerpc

a protoc plugin to generate type safe RPC client and server code that use a message queue for transport/service discovery.

golang message-queue protobuf protocol-buffer pubsub

Last synced: 28 Dec 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/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/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/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/loilo/monomitter

📡 A tiny, overly simplistic event bus

emitter events javascript pubsub signal

Last synced: 31 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/batux/ng-event-bus

ng-event-bus

angularjs eventbus pubsub

Last synced: 17 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/cluster-labs/cosmos

A decentralized communication stack

crdt ipfs libp2p pubsub

Last synced: 17 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/dozyio/gossipsub-simulator

Gossipsub Simulator

gossipsub libp2p pubsub

Last synced: 26 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

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/trailsjs/trailpack-pubsub

Redis Pub/Sub implementation for Trails.js app

pubsub trailpack trails

Last synced: 02 Jan 2025

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/stevenferrer/kafka-pubsub

kafka pub-sub demo

go go-kit golang kafka pubsub

Last synced: 25 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/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/ackeecz/terraform-gcp-pubsub

Terraform module for GCP PubSub resources

gcp pubsub terraform-module

Last synced: 10 Nov 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/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/jharrilim/multiplex

Key-Value store with subscriptions

key pubsub rust store value

Last synced: 31 Dec 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: 08 Jan 2025

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

Publish-subscribe pattern Awesome Lists
Publish-subscribe pattern Categories