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/mguellsegarra/muse-mqtt-audioplayer

🔊 An Arduino sketch for ESP32-based MUSE Luxe board that enables network audio streaming via MQTT control.

arduino arduino-sketch audio-player audio-streaming es8388 esp32 home-automation i2s iot mqtt muse-luxe pubsub smart-speaker wifi

Last synced: 20 Jan 2025

https://github.com/andrewjbateman/cloud-pubsub-firebase

:clipboard: Google Firebase Functions used to transfer data using Pubsub to a Firestore Database

firebase functions google-cloud pubsub tutorial-code typescript3

Last synced: 27 Dec 2024

https://github.com/chocofamilyme/pubsub-life

Библиотека реализует паттерн Pub/Sub

publisher-subscriber pubsub rabbitmq

Last synced: 17 Dec 2024

https://github.com/cyclenerd/google-cloud-pubsub-publish

📨 Small and fast app to publish a message to a Google Cloud Pub/Sub topic

gcp gcp-pubsub go golang google google-cloud google-cloud-platform google-cloud-pubsub message pubsub

Last synced: 20 Dec 2024

https://github.com/saanvijay/weathernotify

Notify the live weather forcast for your current location to the subscribed users. It uses 2 microservices which internally uses 'Confluent's Apache Kafka Golang client'

apache-kafka docker golang microservice pubsub rest-api

Last synced: 14 Dec 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/sshaplygin/go-socket.io-redis-adapter

Redis adapter to enable broadcasting of events to multiple separate go-socket.io server nodes

go-socket-io golang pubsub redis-adapter redis-client socket-io socket-io-adapter

Last synced: 22 Jan 2025

https://github.com/mchmarny/stockercm

Sentiment processor using Cloud Functions, Cloud PubSub, Natural Language Processing API, and Cloud Dataflow.

api cloud dataflow function nlp pubsub

Last synced: 31 Dec 2024

https://github.com/itaditya/state-mgmt-patterns-react

All the ways to manage app state without overly complicating things like Mobx or Redux

context context-api eventbus pubsub react

Last synced: 19 Dec 2024

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

This repo contains the starting point for the Dapr workshop Python challenges.

api cloudnative dapr pubsub state-management

Last synced: 19 Jan 2025

https://github.com/ysskrishna/pixelmotion

A full-stack application built using React, TailwindCSS, FastAPI, Redis, Redis Queue, Docker, and WebSockets. It allows users to generate videos from images with a single click while providing real-time progress updates during the video generation process. The generated videos include animations and background music.

distributed-systems docker docker-compose fastapi package-creation pillow publisher-subscriber pubsub python python-package react reactjs redis redis-queue rq server-sent-events storage-management tailwindcss websocket

Last synced: 25 Jan 2025

https://github.com/kopera/erlang-reg

Alternative Erlang registry

erlang pubsub registry

Last synced: 16 Dec 2024

https://github.com/japrozs/elixir-chat-app

A basic chat app that I made to learn elixir

elxir phoenix presence pubsub webpack

Last synced: 09 Jan 2025

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/nixhantb/distributed-message-broker-engine

Distributed Message Queuing Protocol for Message Broker System

load-balancer message-broker message-queue protocols proxy pubsub queues server tcp

Last synced: 14 Nov 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/whitebolt/topic-subscribe

Universal PubSub module for node and browser with subscription filtering and broadcasting.

angularjs events jquery nodejs pubsub

Last synced: 17 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 Jan 2025

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: 17 Jan 2025

https://github.com/furkankayam/nodejs-zeromq

✅ NodeJs ZeroMQ

nodejs pubsub zeromq

Last synced: 13 Dec 2024

https://github.com/tibel/caerllion.light

Simple asynchronous message bus

async dotnet pubsub

Last synced: 10 Jan 2025

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/tmc/glogs-to-honeycomb

A pubsub pipeline designed to deliver Istio sidecar logs to Honeycomb.

go honeycomb istio pubsub

Last synced: 22 Jan 2025

https://github.com/255bits/pg-async-events

A simple event notification system, pubsub using PostgreSQL

events postgresql pubsub

Last synced: 12 Nov 2024

https://github.com/zkfmapf123/api-gateway-pubsub-pattern

api-gateway + SQS Pub/Sub Pattern

api-gateway aws eventbridge pubsub sqs

Last synced: 17 Dec 2024

https://github.com/samsoft00/email-messaging-service

Service to handle all messaging on Canary point Admin Dashboard, such as email, sms, etc. This service is trigger by Google pub/sub

admin email-service google nodejs pubsub service

Last synced: 17 Dec 2024

https://github.com/molda/pubsub

Simple Publish/Subscribe module

module pubsub totaljs

Last synced: 18 Dec 2024

https://github.com/94dreamer/async-album

Callback/PubSub/Promise/Generator/Redux/RxJS 异步编程实现Demo合集

async callback promise pubsub redux rxjs

Last synced: 18 Dec 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/andrewjbateman/python-functions-pubsub

:clipboard: Google Cloud Functions used to send data using Python code to Google Cloud Pub/Sub where data can be published with a message

cloud-functions pip3 pubsub python3 subscriptions

Last synced: 27 Dec 2024

https://github.com/de3lo/redis-value-cache

An in memory cache backed by redis.

cache pubsub redis

Last synced: 06 Nov 2024

https://github.com/sebastian-nunez/cloud-video-uploader

A fullstack app to showcase the core functionality of a video uploading system using Google Cloud.

cloudrun docker expressjs ffmpeg firebase googlecloud nextjs pubsub react typscript

Last synced: 21 Jan 2025

https://github.com/phogolabs/cloud

Cloud package enables cloudevents.io for server less

cloudevents golang pubsub

Last synced: 23 Jan 2025

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

PubSub design pattern implemented in PHP

php pubsub pubsub-php

Last synced: 17 Jan 2025

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/dataphos/lib-brokers

lib-brokers is a Go library which contains the interfaces used to interact with messaging systems without relying on a specific technology or client library. This library attempts to solve the issue of properly abstracting away the interaction between applications and messaging systems.

cloud-native data-stream data-streaming go jetstream kafka library messaging pubsub pulsar servicebus

Last synced: 19 Jan 2025

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.

pubsub redis rust rust-lang

Last synced: 24 Dec 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/anthonycorletti/modal-async-pubsub-example

A proof-of-concept, pubsub-esque service that runs on Modal.

fastapi modal pubsub python

Last synced: 21 Jan 2025

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

Scalable realtime pub/sub and RPC serverless framework

nodejs pubsub socketcluster typescript websocket

Last synced: 23 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/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/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: 07 Jan 2025

https://github.com/cthtufspetprojects/google-cloud-function-gen2-template

Template for Python functions to run on Google Cloud Functions Platform (gen2), with CI\CD by GitHub Actions

cicd cloudfunctions firestore flask google pre-commit-hooks pubsub python terraform terraform-managed tests

Last synced: 21 Jan 2025

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 Jan 2025

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

Simple demonstration of pub-sub using just event and delegate

pubsub

Last synced: 04 Jan 2025

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

A Non-Standard Message Hub

http hub message pubsub redis

Last synced: 13 Dec 2024

https://github.com/ekaputra07/firesub

Firebase Functions helpers to publish your Cloud Firestore or Cloud Storage events to PubSub. https://www.npmjs.com/package/firesub

cloud-functions firestore gcp pubsub

Last synced: 03 Jan 2025

https://github.com/basedwon/newk

Provides a flexible, transport-layer abstraction for various network protocols

nkn p2p pubsub transport

Last synced: 26 Dec 2024

https://github.com/weiwenchen2022/grpc-pubsub

The Go language implementation of pubsub based on gRPC

go golang grpc protobuf3 pubsub

Last synced: 17 Jan 2025

https://github.com/msysh/aws-sample-appsync-events

This project is a demonstration of a simple and minimal implementation of real-time communication using AWS AppSync Events.

aws-appsync-events pubsub react websocket

Last synced: 26 Dec 2024

https://github.com/slaveofcode/nsq-multi-subscriber

Prove of concept NSQ with multiple worker subscriber

express expressjs node nodejs nsq nsqjs publish pubsub subscribe

Last synced: 20 Jan 2025

https://github.com/cloud8421/oredev-genstage-demo

Elixir GenStage demo application for Oredev 2017 conference

elixir genstage oredev pubsub

Last synced: 13 Jan 2025

https://github.com/sakin790/redis

Redis | Docker | Caching | Api

docker node pubsub redis

Last synced: 22 Jan 2025

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: 03 Jan 2025

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: 09 Jan 2025

https://github.com/syucream/embulk-input-pubsub

Google Cloud Pub/Sub input plugin for Embulk.

embulk-plugin pubsub

Last synced: 03 Jan 2025

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 Jan 2025

https://github.com/mdawar/pubsub

A simple and generic publish/subscribe package for Go.

event-bus go message-bus pubsub

Last synced: 25 Jan 2025

https://github.com/apstory/apstorymq

Lightweight Topic-based Restful Messaging API

apstorymq message publish-subscribe pubsub queues restful-api topic

Last synced: 10 Jan 2025

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.

bigquery gcp pubsub terraform

Last synced: 07 Jan 2025

https://github.com/mminer/redis2ws

Rust WebSockets server that broadcasts Redis Pub/Sub messages

pubsub redis rust tungstenite websockets

Last synced: 20 Jan 2025

https://github.com/devphde/authentication.net

Projeto .Net Core para cadastro, login e recuperação de senha de usuário.

clean-architechture clean-architecture csharp docker entity-framework netcore pubsub solid

Last synced: 08 Jan 2025

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: 07 Jan 2025

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: 11 Jan 2025

https://github.com/kvdomingo/autocomeback

Web scraper to pull comeback/debut data from dbkpop and r/kpop

beautifulsoup cloud-functions kpop pubsub python web-scraping

Last synced: 04 Jan 2025

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

Tigase PubSub Component

pubsub tigase xmpp

Last synced: 10 Nov 2024

Publish-subscribe pattern Awesome Lists
Publish-subscribe pattern Categories