Ecosyste.ms: Awesome
An open API service indexing awesome lists of open source software.
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.
- GitHub: https://github.com/topics/pubsub
- Wikipedia: https://en.wikipedia.org/wiki/Publish%E2%80%93subscribe_pattern
- Released: 1987
- Related Topics: message-queue, message-oriented-middleware, message-passing, event-bus, event-handlers, event-listener, message-bus, event-sourcing, observer-pattern, event-driven-programming,
- Aliases: publish-subscribe-pattern, publish-subscribe,
- Last updated: 2024-12-31 00:15:39 UTC
- JSON Representation
https://github.com/mminer/redis2ws
Rust WebSockets server that broadcasts Redis Pub/Sub messages
pubsub redis rust tungstenite websockets
Last synced: 19 Nov 2024
https://github.com/ortense/mediator
A minimalistic and dependency-free event mediator with internal context for front-end.
dependency-free emitter events mediator observer pubsub typescript typescript-library
Last synced: 16 Nov 2024
https://github.com/mk590901/cloud_measurements
Repository contains flutter app interact with toit app on ESP32 controller.
dart flutter grpc pubsub toit toit-language
Last synced: 18 Dec 2024
https://github.com/255bits/pg-async-events
A simple event notification system, pubsub using PostgreSQL
Last synced: 12 Nov 2024
https://github.com/mk590901/measurements
Repository contains app simulator of healthcare measurement device written on 'toit' programming language can be run on ESP32 controller.
grpc pubsub toit toit-language
Last synced: 18 Dec 2024
https://github.com/prosenjitjoy/go-with-nats
Collection of example code used for learning NATS using Go.
key-value message-queue nats-jetstream object-store pubsub request-reply
Last synced: 19 Dec 2024
https://github.com/prosenjitjoy/go-with-pulsar
Demo app to demonstrate Pub/Sub functionality concurrently with Pulsar
pubsub pulsar pulsar-client-go
Last synced: 19 Dec 2024
https://github.com/bitbreakr/go-disperse
Disperse is a Go package that provides a Pub/Sub abstraction layer over unix sockets
cloud communication golang ipc linux macos pubsub socket unix
Last synced: 02 Dec 2024
https://github.com/mdawar/pubsub
A simple and generic topic-based publish/subscribe package for in-process communication in Go.
event-bus go message-bus pubsub
Last synced: 26 Nov 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: 09 Nov 2024
https://github.com/guillempuche/adu
The initial version of a chatbot. Goal: improve the communication of the universities with their students.
auth0 authentication chat chatbot domain-driven-design jwt material-ui mongodb nodejs nosql pubsub react tdd
Last synced: 15 Dec 2024
https://github.com/wspietro/google-pubsub-service
Message service using Google Cloud Pub/Sub between two independent applications (order service and packaging service).
fastify google-pubsub nodejs pubsub typescript
Last synced: 12 Nov 2024
https://github.com/inottn/unsubber
Based on mitt, simplifying event handling.
Last synced: 26 Nov 2024
https://github.com/wspietro/cloud-pubsub-publisher
Google Cloud Pub/Sub with a Fastify server.
cloud-pub-sub fastify google-pubsub nodejs pubsub
Last synced: 12 Nov 2024
https://github.com/pantheon-systems/pubsub-cleaner
Clean up subscriptions in GCE PubSub
gce go kubernetes platfrastructure pubsub sig-golang sig-tools
Last synced: 11 Nov 2024
https://github.com/timwienk/wow-libpubsub-1-0
World of Warcraft AddOn library. Simple embeddable publish-subscribe implementation.
library lua pubsub world-of-warcraft world-of-warcraft-addon
Last synced: 02 Dec 2024
https://github.com/naman-45/bitcoints
aes-gcm express nextjs postgresql prisma-orm pubsub redis singleton-pattern websocket
Last synced: 20 Dec 2024
https://github.com/ju5tu5/pubsub
It's a really small demonstration of the publish subscribe pattern in javascript.
Last synced: 28 Nov 2024
https://github.com/squidmin/spring-gradle-pubsub-subscriber-reference
Template for a Google Cloud Pub/Sub subscriber using Spring Boot and Gradle
event-driven gcp google-cloud-platform gradle java java17 java17-spring-boot pubsub spring-boot spring-boot-3
Last synced: 14 Dec 2024
https://github.com/apstory/apstory-lib-angular
Apstory Angular 7 Libraries
aes-256 angular6 angular7 apstorymq dnn dnn-angular-navigation dnn-navigation dotnetnuke message-broker-client message-bus message-queue publish publish-subscribe pubsub subscribe topic typescipt
Last synced: 20 Dec 2024
https://github.com/iht/bigquery-dataflow-cdc-example
A Dataflow streaming pipeline written in Java, reading data from Pubsub and recovering the sessions from potentially unordered data, and upserting the session data into BigQuery with no duplicates
apache-beam bigquery cdc dataflow google-cloud pubsub
Last synced: 29 Dec 2024
https://github.com/killercodemonkey/graphql-pub-sub-with-initial-value
GraphQL PubSub with intial value handling
apollo apollo-server graphql pubsub subscription
Last synced: 06 Dec 2024
https://github.com/daalvand/pub-sub
This package used to publish and subscribe with Regis or Kafka
kafka laravel pub-sub publish-subscribe pubsub redis
Last synced: 23 Dec 2024
https://github.com/joeychilson/pghook
A Go library for executing hooks on insert, update, and delete events in PostgreSQL.
events go golang hooks postgres postgresql pubsub
Last synced: 16 Nov 2024
https://github.com/fusetim/ipfs-pubsub-mod
Enable PubSub experimental feature for IPFS (https://github.com/linuxserver/docker-ipfs)
docker docker-container docker-ipfs docker-mods experimental experimental-features go-ipfs ipfs kubernetes mods pubsub
Last synced: 20 Dec 2024
https://github.com/frankie567/pubsub-emulator-alpine
Google Cloud Pub/Sub emulator Docker image, based on Alpine linux
Last synced: 16 Dec 2024
https://github.com/trandung2k1/express_microservice_redis
api-gateway expressjs microservice pubsub redis
Last synced: 29 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 Nov 2024
https://github.com/ppkgtmm/network-project-mqtt
MQTT protocol simulator using socket programming
Last synced: 25 Nov 2024
https://github.com/chinmayvivek/rust-redis-pub-sub
This project demonstrates a simple Pub/Sub (Publish/Subscribe) integration with Redis using Rust. It includes examples of a Redis publisher and subscriber, showcasing how to send and receive messages. Redis is run using Docker for ease of setup and management.
Last synced: 24 Dec 2024
https://github.com/lafayettegabe/simple-event-stream
📨 SES: A simple event-driven PoC using NATS for real-time Pub/Sub messaging
docker docker-compose event-driven event-driven-architecture go golang javascript nats pubsub stream streaming
Last synced: 16 Dec 2024
https://github.com/code-raushan/chat-server-ws
Implementation of a scalable chat server using Websockets and Redis pub/sub in Go.
chat-server go pubsub redis scale websocket
Last synced: 15 Dec 2024
https://github.com/semihbkgr/spring-chat
Spring chat application sample built using Redis pub-sub and STOMP
messaging pubsub redis spring-boot stomp websocket
Last synced: 04 Dec 2024
https://github.com/rtradeltd/issues
meta-repository that tracks active issues that are looking for code contributions
collaboration contribute crypto ipfs ipns open-source pubsub rtradeltd temporal
Last synced: 11 Nov 2024
https://github.com/m7moudgadallah/backend-fundamentals-demos
Dive into essential backend concepts with practical demos.
backend communication-patterns nodejs polling pubsub push sidecar
Last synced: 01 Jan 2025
https://github.com/andrefcruz/feup-asso
Repository to host our 'Software Architecture' project, a 4th year unit @FEUP.
pipes-and-filters pubsub software-architecture
Last synced: 20 Dec 2024
https://github.com/cxres/id-pre-test-2
Internet Draft for the Per Resource Events Test
events http notifications protocol pubsub
Last synced: 04 Dec 2024
https://github.com/salmandabbakuti/aws-sns-essentials
AWS SNS&SQS Setup and workaround repository
aws aws-sdk aws-sqs notifications pubsub sns sns-client sns-topic sqs sqs-client topic
Last synced: 09 Nov 2024
https://github.com/raulpe7eira/course-groxio-liveview
Grox.io Learning's Professional LiveView Course by Bruce Tate
ecto elixir groxio liveview phoenix pubsub svg tailwind-css
Last synced: 19 Dec 2024
https://github.com/rene78/popcompics
PopComPics (Popular Commons Pics) shows you how many times each picture of a certain Commons user has been utilized in Wikimedia projects.
autocompletejs chartjs mediawiki-api no-framework popularity-analysis pubsub vanilla-javascript wikimedia wikimedia-api wikimedia-commons wikipedia
Last synced: 09 Oct 2024
https://github.com/fastybird/redisdb-plugin
:busstop: [READ-ONLY] FastyBird IoT data storage & exchange plugin for Redis database
exchange fastybird fb iot nette php plugin pubsub redis redis-client state state-management
Last synced: 10 Oct 2024
https://github.com/getlarge/loopback-pubsub-component
Generic pubsub component for loopback 4
amqp bridge component loopback4 mqtt-client pubsub redis
Last synced: 21 Dec 2024
https://github.com/zsoulaimane/api-and-network-blockchain
block blockchain express hash javascript json nodejs postman pubsub redis testing
Last synced: 08 Nov 2024
https://github.com/hhow09/go-chatrooms
chatroom chatroom-server golang pubsub redis
Last synced: 10 Dec 2024
https://github.com/ritreshgirdhar/newsfeed-elixir-phoenix-kafka-integration
News Feed Application
elixir elixir-lang elixir-phoenix elixir-programming-language kafka kafka-consumer pubsub reactive-programming
Last synced: 25 Dec 2024
https://github.com/flowerinthenight/longsub
Package for lengthy subscriptions for AWS SQS and GCP Pub/Sub.
aws gcp lengthy pubsub sqs subscription
Last synced: 10 Nov 2024
https://github.com/pnu/gcr-trigger-build-wip
**work in progress** – Trigger Cloud Build jobs when new tags are inserted to GCR or webhook called.I've implemented similar for Cloud Run and at least for the current use-case it seems to be better fit.. but I'll save this here for later reference.
cloudbuild gcf gcloud gcr pubsub secrets-manager wip
Last synced: 09 Nov 2024
https://github.com/mchmarny/custommetrics
Custom Stackdriver metrics from Cloud PubSub payload
function gcf gcp goalng pubsub stackdriver
Last synced: 31 Dec 2024
https://github.com/limitium/mqttwifi
robust mqtt client over wifi for ESP8266 and ESP32
esp32 esp32-library esp8266 esp8266-library mqtt mqtt-client pubsub wifi
Last synced: 12 Nov 2024
https://github.com/tmc/glogs-to-honeycomb
A pubsub pipeline designed to deliver Istio sidecar logs to Honeycomb.
Last synced: 13 Dec 2024
https://github.com/vtopc/wcache
In-memory cache with write-back strategy. DO NOT USE, it's very slow.
cache cache-storage custom-callback expiration expiration-callback go golang graceful-shutdown in-memory-caching in-memory-storage lazy-writers pubsub trigger ttl write-back write-behind
Last synced: 25 Dec 2024
https://github.com/icukeng/docker-rabbitmq-pshb
rabbithub docker image
docker pubsub pubsubhubbub rabbithub rabbitmq
Last synced: 09 Nov 2024
https://github.com/wiseaidev/emitter-rs
📢 A lightweight Event Emitter implementation for Rust and Wasm.
emitter event-emitter pubsub rust wasm
Last synced: 22 Oct 2024
https://github.com/ditsuke/kafka-pubsub
Apache Kafka pub/sub clients and benchmarks
Last synced: 08 Nov 2024
https://github.com/cevheri/java-kafka-jhipster-example
Java Kafka Publish And Subscribe Example
docker docker-compose java jhipster kafka pubsub zookeeper
Last synced: 09 Nov 2024
https://github.com/syucream/embulk-input-pubsub
Google Cloud Pub/Sub input plugin for Embulk.
Last synced: 09 Nov 2024
https://github.com/ayush272002/exchange
Cryptocurrency exchange platform designed to handle high-frequency trading and real-time market interactions.
expressjs monorepo nextjs postgresql pubsub redis turborepo websocket
Last synced: 19 Dec 2024
https://github.com/ackeecz/terraform-gcp-cloud-function_pubsub_to_bq
Cloud function subscribes itself to given topic and inserts each message to BigQuery table.
bigquery cloud-functions pubsub terraform-module
Last synced: 10 Nov 2024
https://github.com/edgartec97/sam_users_jwt
USERS_API micro-service (Backend) with AWS Serverless Architecture
aws aws-lambda aws-layers aws-sam ci-cd clean-architecture cloudformation cognito docker dynamodb event-bridge github-actions localstack nodejs pubsub s3 sns sqs typescript
Last synced: 17 Dec 2024
https://github.com/ackeecz/terraform-gcp-cloud-run_pubsub_to_bq
Cloud Run subscribes itself to given topic and inserts each message to BigQuery table.
Last synced: 10 Nov 2024
https://github.com/wildonion/rediscord
👾 a simple example of discord and redis pusbub channel, publish twitter mentions to redis in twidis bot and subscribe to them in discord bot in rust to send them in a discord channel
discord-bot mutex-lock pubsub redis tokio-rs
Last synced: 07 Nov 2024
https://github.com/akaliutau/gke-pubsub
A simple research project to study HPA technology on Kubernetes cluster
autoscaling gke-cluster hpa java11-spring-boot kubernetes pubsub terraform
Last synced: 12 Nov 2024
https://github.com/ngmy/php-observer
A PHP library to implement the observer pattern
design-pattern event event-handler event-listener library observer observer-pattern php php-library publisher pubsub subject subscriber
Last synced: 12 Dec 2024
https://github.com/navneethvi/nats-centralized-microservices
Explore microservice communication with Node.js and NATS in our demo ticketing app. Experience seamless scalability and lightning-fast messaging. Dockerized for easy deployment, it showcases service discovery and real-world ticketing scenarios.
docker events expressjs ingress-nginx kubernetes microservices nats-streaming-server nodejs pubsub skaffold
Last synced: 10 Nov 2024
https://github.com/techgaun/gproc_pubsub
A simple wrapper on top of gproc for your pubsub needs - untested
Last synced: 19 Dec 2024
https://github.com/austinjhunt/vanderbiltcs6381-assignment1-zmqpubsub
This project offers a framework for spinning up a publish/subscribe system either on a single host or on a virtualized network with a tool like Mininet.
distributed mininet pubsub python zmq
Last synced: 15 Nov 2024
https://github.com/kubescape/messaging
Kubescape's messaging package - a collection of wrapper code around Pulsar to quickly and easily connect to Pulsar brokers, send and receive messages, and message queues and topics management.
message-broker messaging pubsub pulsar
Last synced: 15 Nov 2024
https://github.com/frarosset/battleship
A project from The Odin Project (Full Stack Javascript).
battleship battleship-game css css3 drag-and-drop html html5 javascript pubsub theodinproject webpack
Last synced: 17 Nov 2024
https://github.com/frarosset/weather-app
A project from The Odin Project (Full Stack Javascript).
css css3 html html5 javascript localstorage lottie lottie-web meteocons pubsub theodinproject visual-crossing visual-crossing-api weather-app webpack
Last synced: 17 Nov 2024
https://github.com/gnodivad/laravel-broadcast
laravel laravel-echo-server pubsub redis
Last synced: 20 Nov 2024
https://github.com/umran/mq
A Cloud-Agnostic Go Library for Publishing to and Consuming from Message Queues
aws aws-sns-sqs broker gcp google-cloud-pubsub message messaging mq pubsub queue sns sqs subscription topic
Last synced: 27 Dec 2024
https://github.com/zleao/zoft.notificationservice
Generic C# messaging service to allow communication between modules
csharp messaging netstandard20 notification pubsub zoft
Last synced: 07 Dec 2024
https://github.com/iadtya/scalable-chatterup
Scalable-ChatterUp is group chat application Built with event-driven architecture using WebSockets for real-time client-server communication Redis for pub/sub messaging with Sentinel and replica for high availability, and Kafka for message queuing. Data ingestion was handled through PostgreSQL
kafka nextjs pubsub redis-sentinel socket-io turborepo typescript
Last synced: 09 Nov 2024
https://github.com/topgunbuild/socket
Scalable realtime pub/sub and RPC serverless framework
nodejs pubsub socketcluster typescript websocket
Last synced: 23 Nov 2024
https://github.com/52north/kafka-sos-consumer
debezium kafka kafka-connect observations pubsub sensorweb sos
Last synced: 14 Dec 2024
https://github.com/terance-edmonds/python-pub-sub
Designing and implementing a simple Publish and Subscribe middleware using Client-Server Sockets Programming concepts and techniques
pubsub python socket-programming
Last synced: 15 Nov 2024
https://github.com/ramadani/clinci
Event Listener using RabbitMQ Pub/Sub
event-driven event-listener golang-package message-broker publisher-subscriber pubsub queue rabbitmq
Last synced: 13 Dec 2024
https://github.com/lostintime/node-multiconsumer-queue
A wrapper to build multi-consumer queues on NodeJS
Last synced: 20 Nov 2024
https://github.com/gabrieljoelc/la_gear
Use conventions to generate publish/subscribe workers
distributed-systems pubsub rabbitmq redis ruby sidekiq
Last synced: 12 Nov 2024
https://github.com/jaandrle/fpubsub
PubSub pattern library with types support
event event-emitter functional-programming javascript pub-sub pubsub reactive reactive-programming typescript
Last synced: 21 Dec 2024
https://github.com/nadahamdy217/movies-data-etl-using-python-gcp
Developed a comprehensive ETL pipeline for movie data using Python, Docker, and a GCP Pub/Sub emulator. Successfully processed and published the data in a local Docker environment, showcasing advanced data engineering skills.
analytics data data-engineering data-ingestion data-preparation data-preprocessing data-processing data-project docker etl etl-pipeline gcp matplotlib matplotlib-pyplot numpy pandas pubsub python scipy seaborn
Last synced: 06 Dec 2024