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

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

message-queue pubsub ruby

Last synced: 05 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/moonshrd/p2chat-android

Port of p2chat to Android

android iot libp2p mesh pubsub

Last synced: 26 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/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/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/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/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/jeroengerits/godot-pubsub

PubSub Library in GDScript for the Godot Engine

addon gdscript godot pubsub

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

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

pub-sub pubsub

Last synced: 20 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/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 Nov 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/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/zekrotja/eventbus

A go package to send and receive pub-sub messages using channels.

event-driven eventbus events go go118 gogeneric hacktoberfest pubsub

Last synced: 17 Dec 2024

https://github.com/developer-guy/bookmark-searcher

Making bookmark search using Redis Cloud,ELK

elasticsearch elk go golang kibana logstash pubsub redis redis-cloud redis-labs

Last synced: 13 Dec 2024

https://github.com/roylee0704/centrifugo-example

running centrifugo in docker

centrifuge centrifugo nodejs pubsub

Last synced: 20 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/platdesign/cana

rx-pubsub

nodejs pubsub rx ws

Last synced: 19 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/mchmarny/xstreams

Stream processing using Cloud PubSub and Dataflow SQL in BigQuery

bigquery dataflow gce gcp golang pubsub stream

Last synced: 08 Nov 2024

https://github.com/mchmarny/godapr

Simple dapr HTTP client library

client dapr go grpc pubsub

Last synced: 08 Nov 2024

https://github.com/mchmarny/artomator

Automates creation of Software Bill of Materials (SBOM) with Binary Authorization attestation for container images in Artifact Registry.

artifact authorization devops gcp google-cloud-platform pubsub registry sbom

Last synced: 08 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/mchmarny/dapr-http-event-subscriber-template

Template project to jump start your Dapr development in Go for HTTP service that will be triggered by topic events

dapr eventing go pubsub service state topic

Last synced: 08 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/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/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/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/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/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/ragmaanir/besked

Small typed PubSub library for crystal.

crystal pubsub

Last synced: 14 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/molda/pubsub

Simple Publish/Subscribe module

module pubsub totaljs

Last synced: 18 Dec 2024

https://github.com/develephant/noobhub-install

NoobHub Installer for a DigitalOcean NodeJS Droplet

corona digitalocean installer multiplayer nodejs noobhub pubsub

Last synced: 22 Dec 2024

https://github.com/rudsarkar/pubsub-websocket

WebSocket pub/sub implementation usin Go gin, Postgresql

gin-gonic golang postgresql pubsub websocket

Last synced: 07 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/ket0825/v1-gcp-preview

Preview 서비스를 위한 GCP 레포 / Manage GCP src for preview services

bigquery cloud-functions cloud-run cloudbuild gcp logging pubsub

Last synced: 21 Nov 2024

https://github.com/anpandu/ps2bq

Stream insert GCP PubSub messages into BigQuery table.

bigquery golang pubsub

Last synced: 21 Nov 2024

https://github.com/ankush-web-eng/lc-architecture

A repo where I practiced LeetCode backend architecture with advanced backend concepts and tested each one of them.

captcha ddos-attacks expressjs nodejs pubsub queues rate-limiting redis

Last synced: 16 Nov 2024

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

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

publisher-subscriber pubsub rabbitmq

Last synced: 17 Dec 2024

https://github.com/lpil/progress

A service that keeps track of progress and publishes updates to subscribers

api elixir lua microservice pubsub redis

Last synced: 21 Nov 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/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: 21 Nov 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/ankush-web-eng/brolangf

BROLANG is a programming language built for fun written in golang.

brolang golang kafka nextjs15 pubsub queue redis tailwindcss websockets-server

Last synced: 16 Nov 2024

https://github.com/swift-libp2p/swift-libp2p-pubsub

A Publish-Subscribe library for peer to peer messaging within libp2p

floodsub gossipsub libp2p libp2p-pubsub networking p2p pubsub swift

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

https://github.com/cunkz/google-pubsub-nodejs

Example using Google Pub/Sub via NodeJS.

google google-cloud-platform nodejs pubsub

Last synced: 25 Nov 2024

https://github.com/cunkz/google-cloud-function-pubsub-to-firestore

Function for Google Cloud Function to CRUD from Pub/Sub to Firestore

cloud-function firebase firestore google google-cloud-platform nodejs pubsub

Last synced: 25 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/topgunbuild/socket

Scalable realtime pub/sub and RPC serverless framework

nodejs pubsub socketcluster typescript websocket

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

https://github.com/ppkgtmm/network-project-mqtt

MQTT protocol simulator using socket programming

mqtt pubsub python

Last synced: 25 Nov 2024

https://github.com/disk0dancer/chat-app

Multi user online chat based on different services communication approaches

fastapi pubsub python3 react rest-api typescript websockets

Last synced: 06 Dec 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/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/janaom/gcp-de-project-streaming-pubsub-beam-dataflow

This project demonstrates an end-to-end solution for processing and analyzing real-time conversations data from a JSON file using GCP services and infrastructure automation, showcasing data storage, streaming, processing, and analysis at scale.

apache-beam bigquery dataflow de-project gcp pubsub streaming-data

Last synced: 19 Nov 2024

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

https://github.com/mukil/dmx-notifications

Realizes persistent notifications for users of DMX across sessions and screens.

deepamehta notifications plugin pubsub websockets

Last synced: 22 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/frarosset/todo-list

A project from The Odin Project (Full Stack Javascript).

css css3 html html5 javascript localstorage pubsub theodinproject todo-list todolist webpack

Last synced: 29 Nov 2024

https://github.com/phogolabs/cloud

Cloud package enables cloudevents.io for server less

cloudevents golang pubsub

Last synced: 23 Nov 2024

https://github.com/mchmarny/custommetrics

Custom Stackdriver metrics from Cloud PubSub payload

function gcf gcp goalng pubsub stackdriver

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

bigquery gcp pubsub terraform

Last synced: 10 Nov 2024

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: 09 Nov 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: 20 Nov 2024

https://github.com/marcominerva/azurewebpubsub

A collection of samples about Azure Web PubSub Service

azure pubsub websock

Last synced: 19 Nov 2024

https://github.com/lnk2past/toadofsky

educational toy project for multithreaded orchestration + pubsub

cpp cpp20 multithreading orchestration pubsub

Last synced: 22 Nov 2024

https://github.com/hlts2/gopubsub

Simple lock-free topick based publish/subscribe library written in golang

golang golang-library goroutine-safe goroutines hlts2 library lock-free pubsub pubsub-instance pubsub-messages topic

Last synced: 19 Nov 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/paujim/gcp-app

A sample app in python

appengine pubsub python

Last synced: 02 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/bnb32/modbot

This moderation bot software uses scikit-learn binary classification algorithms or pytorch neural networks to learn what phrases to allow in twitch chat. Labeled training data is constructed from chat logs with human moderation information. After training the software can be connected to twitch chat to automate moderation.

irc-bot machine-learning moderation-bot pubsub twitch

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

Publish-subscribe pattern Awesome Lists
Publish-subscribe pattern Categories