Name | django-kafka JSON |
Version |
0.5.9
JSON |
| download |
home_page | None |
Summary | Confluent's Kafka Python Client combined with Django |
upload_time | 2024-11-28 15:24:01 |
maintainer | None |
docs_url | None |
author | None |
requires_python | >=3.11 |
license | Copyright 2024 RegioHelden GmbH Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation files (the "Software”), to deal in the Software without restriction, including without limitation the rights to use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the Software is furnished to do so, subject to the following conditions: The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software. THE SOFTWARE IS PROVIDED "AS IS”, WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE. |
keywords |
django
kafka
|
VCS |
|
bugtrack_url |
|
requirements |
No requirements were recorded.
|
Travis-CI |
No Travis.
|
coveralls test coverage |
No coveralls.
|
# django-kafka
This library is using [confluent-kafka-python](https://github.com/confluentinc/confluent-kafka-python) which is a wrapper around the [librdkafka](https://github.com/confluentinc/librdkafka) (Apache Kafka C/C++ client library).
It helps to integrate kafka with Django.
## Quick start
```bash
pip install django-kafka
```
### Configure:
Considering you have locally setup kafka instance with no authentication. All you need is to define the bootstrap servers.
```python
# ./settings.py
INSTALLED_APPS = [
# ...
"django_kafka",
]
DJANGO_KAFKA = {
"GLOBAL_CONFIG": {
"bootstrap.servers": "kafka1:9092",
},
}
```
### Define a Topic:
Topics define how to handle incoming messages and how to produce an outgoing message.
```python
from confluent_kafka.serialization import MessageField
from django_kafka.topic import Topic
class Topic1(Topic):
name = "topic1"
def consume(self, msg):
key = self.deserialize(msg.key(), MessageField.KEY, msg.headers())
value = self.deserialize(msg.value(), MessageField.VALUE, msg.headers())
# ... process values
```
`Topic` inherits from the `TopicProducer` and `TopicConsumer` classes. If you only need to consume or produce messages, inherit from one of these classes instead to avoid defining unnecessary abstract methods.
### Define a Consumer:
Consumers define which topics they take care of. Usually you want one consumer per project. If 2 consumers are defined, then they will be started in parallel.
Consumers are auto-discovered and are expected to be located under the `some_django_app/kafka/consumers.py` or `some_django_app/consumers.py`.
```python
# ./consumers.py
from django_kafka import kafka
from django_kafka.consumer import Consumer, Topics
from my_app.topics import Topic1
# register your consumer using `DjangoKafka` class API decorator
@kafka.consumers()
class MyAppConsumer(Consumer):
# tell the consumers which topics to process using `django_kafka.consumer.Topics` interface.
topics = Topics(
Topic1(),
)
config = {
"group.id": "my-app-consumer",
"auto.offset.reset": "latest",
"enable.auto.offset.store": False,
}
```
### Start the Consumers:
You can use django management command to start defined consumers.
```bash
./manage.py kafka_consume
```
Or you can use `DjangoKafka` class API.
```python
from django_kafka import kafka
kafka.run_consumers()
```
Check [Confluent Python Consumer](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#consumer) for API documentation.
### Produce:
Message are produced using a Topic instance.
```python
from my_app.topics import Topic1
# this will send a message to kafka, serializing it using the defined serializer
Topic1().produce("some message")
```
Check [Confluent Python Producer](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#producer) for API documentation.
### Define schema registry:
The library is using [Confluent's SchemaRegistryClient](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#schemaregistryclient). In order to use it define a `SCHEMA_REGISTRY` setting.
Find available configs in the [SchemaRegistryClient docs](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#schemaregistryclient).
```python
DJANGO_KAFKA = {
"SCHEMA_REGISTRY": {
"url": "http://schema-registry",
},
}
```
**Note:** take [django_kafka.topic.AvroTopic](./django_kafka/topic.py) as an example if you want to implement a custom Topic with your schema.
## Specialized Topics:
### ModelTopicConsumer:
`ModelTopicConsumer` can be used to sync django model instances from abstract kafka events. Simply inherit the class, set the model, the topic to consume from and define a few abstract methods.
```py
from django_kafka.topic.model import ModelTopicConsumer
from my_app.models import MyModel
class MyModelConsumer(ModelTopicConsumer):
name = "topic"
model = MyModel
def is_deletion(self, model, key, value) -> bool:
"""returns if the message represents a deletion"""
return value.pop('__deleted', False)
def get_lookup_kwargs(self, model, key, value) -> dict:
"""returns the lookup kwargs used for filtering the model instance"""
return {"id": key}
```
Model instances will have their attributes synced from the message value. If you need to alter a message key or value before it is assigned, define a `transform_{attr}` method:
```python
class MyModelConsumer(ModelTopicConsumer):
...
def transform_name(model, key, value):
return 'first_name', value["name"].upper()
```
### DbzModelTopicConsumer:
`DbzModelTopicConsumer` helps sync model instances from [debezium source connector](https://debezium.io/documentation/reference/stable/architecture.html) topics. It inherits from `ModelTopicConsumer` and defines default implementations for `is_deletion` and `get_lookup_kwargs` methods.
In Debezium it is possible to [reroute records](https://debezium.io/documentation/reference/stable/transformations/topic-routing.html) from multiple sources to the same topic. In doing so Debezium [inserts a table identifier](https://debezium.io/documentation/reference/stable/transformations/topic-routing.html#_ensure_unique_key) to the key to ensure uniqueness. When this key is inserted, you **must instead** define a `reroute_model_map` to map the table identifier to the model class to be created.
```py
from django_kafka.topic.debezium import DbzModelTopicConsumer
from my_app.models import MyModel, MyOtherModel
class MyModelConsumer(DbzModelTopicConsumer):
name = "debezium_topic"
reroute_model_map = {
'public.my_model': MyModel,
'public.my_other_model': MyOtherModel,
}
```
A few notes:
1. The connector must be using the [event flattening SMT](https://debezium.io/documentation/reference/stable/transformations/event-flattening.html) to simplify the message structure.
2. [Deletions](https://debezium.io/documentation/reference/stable/transformations/event-flattening.html#extract-new-record-state-delete-tombstone-handling-mode) are detected automatically based on a null message value or the presence of a `__deleted` field.
3. The message key is assumed to contain the model PK as a field, [which is the default behaviour](https://debezium.io/documentation/reference/stable/connectors/postgresql.html#postgresql-property-message-key-columns) for Debezium source connectors. If you need more complicated lookup behaviour, override `get_lookup_kwargs`.
## Dead Letter Topic:
Any message which fails to consume will be sent to the dead letter topic. The dead letter topic name is combined of the consumer group id, the original topic name, and a `.dlt` suffix (controllable with the `DEAD_LETTER_TOPIC_SUFFIX` setting). So for a failed message in `topic` received by consumer `group`, the dead letter topic name would be `group.topic.dlt`.
## Retries:
Add retry behaviour to a topic by using the `retry` decorator:
```python
from django_kafka import kafka
from django_kafka.topic import Topic
@kafka.retry(max_retries=3, delay=120, include=[ValueError])
class RetryableTopic(Topic):
name = "topic"
...
```
You can also configure retry behaviour globally for all topics with the `RETRY_SETTINGS` configuration (see [settings](#settings)).
Retries can be either blocking or non-blocking, controlled by the `blocking` boolean parameter. By default, all retries are blocking.
### Blocking Retries:
When the consumption of a message fails in a blocking retryable topic, the consumer process will pause the partition and retry the message at a later time. Therefore, messages in that partition will be blocked until the failing message succeeds or the maximum retry attempts are reached, after which the message is sent to the dead letter topic.
### Non-blocking Retries:
When the consumption of a message fails in a non-blocking retryable topic, the message is re-sent to a topic with a name combined of the consumer group id, the original topic name, a `.retry` suffix (controllable with the `RETRY_TOPIC_SUFFIX` setting), and the retry number. Subsequent failed retries will then be sent to retry topics of incrementing retry number until the maximum attempts are reached, after which it will be sent to a dead letter topic. So for a failed message in topic `topic`, with a maximum retry attempts of 3 and received by consumer group `group`, the expected topic sequence would be:
1. `topic`
2. `group.topic.retry.1`
3. `group.topic.retry.2`
4. `group.topic.retry.3`
5. `group.topic.dlt`
When consumers are started using [start commands](#start-the-Consumers), an additional retry consumer will be started in parallel for any consumer containing a non-blocking retryable topic. This retry consumer will be assigned to a consumer group whose id is a combination of the original group id and a `.retry` suffix. This consumer is subscribed to the retry topics, and manages the message retry and delay behaviour. Please note that messages are retried directly by the retry consumer and are not sent back to the original topic.
## Connectors:
Connectors are auto-discovered and are expected to be located under the `some_django_app/kafka/connectors.py` or `some_django_app/connectors.py`.
Connectors are defined as python classes decorated with `@kafka.connectors()` which adds the class to the global registry.
`django_kafka.connect.connector.Connector` implements submission, validation and deletion of the connector configuration.
### Define connector:
```python
# Connectors are discovered automatically when placed under the connectors module
# e.g. ./connectors.py
from django_kafka import kafka
from django_kafka.connect.connector import Connector
@kafka.connectors()
class MyConnector(Connector):
config = {
# configuration for the connector
}
```
### Mark a connector for removal:
```python
from django_kafka import kafka
from django_kafka.connect.connector import Connector
@kafka.connectors()
class MyConnector(Connector):
mark_for_removal = True
config = {
# configuration for the connector
}
```
### Manage connectors:
django-kafka provides `./manage.py kafka_connect` management command to manage your connectors.
#### Manage a single connector
```bash
./manage.py kafka_connect path.to.my.SpecialConnector --validate --publish --check-status --ignore-failures
````
#### Manage all connectors
```bash
./manage.py kafka_connect --validate --publish --check-status --ignore-failures
````
`--validate` - validates the config over the connect REST API
`--publish` - create or update the connector or delete when `mark_for_removal = True`
`--check-status` - check the status of the connector is `RUNNING`.
`--ignore-failures` - command wont fail if any of the connectors fail to validate or publish.
See `--help`.
## Settings:
**Defaults:**
```python
DJANGO_KAFKA = {
"CLIENT_ID": f"{socket.gethostname()}-python",
"ERROR_HANDLER": "django_kafka.error_handlers.ClientErrorHandler",
"GLOBAL_CONFIG": {},
"PRODUCER_CONFIG": {},
"CONSUMER_CONFIG": {},
"RETRY_CONSUMER_CONFIG": {
"auto.offset.reset": "earliest",
"enable.auto.offset.store": False,
"topic.metadata.refresh.interval.ms": 10000,
},
"RETRY_SETTINGS": None,
"RETRY_TOPIC_SUFFIX": "retry",
"DEAD_LETTER_TOPIC_SUFFIX": "dlt",
"POLLING_FREQUENCY": 1, # seconds
"SCHEMA_REGISTRY": {},
# Rest API of the kafka-connect instance
"CONNECT_HOST": None,
# `requests.auth.AuthBase` instance or tuple of (username, password) for Basic Auth
"CONNECT_AUTH": None,
# kwargs for `urllib3.util.retry.Retry` initialization
"CONNECT_RETRY": dict(
connect=5,
read=5,
status=5,
backoff_factor=0.5,
status_forcelist=[502, 503, 504],
),
# `django_kafka.connect.client.KafkaConnectSession` would pass this value to every request method call
"CONNECT_REQUESTS_TIMEOUT": 30,
"CONNECTOR_NAME_PREFIX": "",
}
```
#### `CLIENT_ID`
Default: `f"{socket.gethostname()}-python"`
An id string to pass to the server when making requests. The purpose of this is to be able to track the source of requests beyond just ip/port by allowing a logical application name to be included in server-side request logging.
**Note:** This parameter is included in the config of both the consumer and producer unless `client.id` is overwritten within `PRODUCER_CONFIG` or `CONSUMER_CONFIG`.
#### `GLOBAL_CONFIG`
Default: `{}`
Defines configurations applied to both consumer and producer. See [configs marked with `*`](https://github.com/confluentinc/librdkafka/blob/master/CONFIGURATION.md).
#### `PRODUCER_CONFIG`
Default: `{}`
Defines configurations of the producer. See [configs marked with `P`](https://github.com/confluentinc/librdkafka/blob/master/CONFIGURATION.md).
#### `CONSUMER_CONFIG`
Default: `{}`
Defines configurations of the consumer. See [configs marked with `C`](https://github.com/confluentinc/librdkafka/blob/master/CONFIGURATION.md).
#### `RETRY_CONSUMER_CONFIG`
Default:
```py
{
"auto.offset.reset": "earliest",
"enable.auto.offset.store": False,
"topic.metadata.refresh.interval.ms": 10000,
}
```
Defines configuration for the retry consumer. See [Non-blocking retries](#non-blocking-retries).
#### `RETRY_TOPIC_SUFFIX`
Default: `retry`
Defines the retry topic suffix. See [Non-blocking retries](#non-blocking-retries).
#### `RETRY_SETTINGS`
Default: `None`
Defines the default retry settings. See [retries](#retries).
#### `DEAD_LETTER_TOPIC_SUFFIX`
Default: `dlt`
Defines the dead letter topic suffix. See [Dead Letter Topic](#dead-letter-topic).
#### `POLLING_FREQUENCY`
Default: 1 # second
How often client polls for events.
#### `SCHEMA_REGISTRY`
Default: `{}`
Configuration for [confluent_kafka.schema_registry.SchemaRegistryClient](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#schemaregistryclient).
#### `ERROR_HANDLER`
Default: `django_kafka.error_handlers.ClientErrorHandler`
This is an `error_cb` hook (see [Kafka Client Configuration](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#kafka-client-configuration) for reference).
It is triggered for client global errors and in case of fatal error it raises `DjangoKafkaError`.
#### `CONNECT_HOST`
Default: `None`
Rest API of the kafka-connect instance.
#### `CONNECT_AUTH`
Default: `None`
`requests.auth.AuthBase` instance or `("username", "password")` for Basic Auth.
#### `CONNECT_AUTH`
Default: `dict(
connect=5,
read=5,
status=5,
backoff_factor=0.5,
status_forcelist=[502, 503, 504],
)`
kwargs for `urllib3.util.retry.Retry` initialization.
#### `CONNECT_REQUESTS_TIMEOUT`
Default: `30`
`django_kafka.connect.client.KafkaConnectSession` would pass this value to every request method call.
#### `CONNECTOR_NAME_PREFIX`
Default: `""`
Prefix which will be added to the connector name when publishing the connector.
`CONNECT_` settings are required for `./manage.py kafka_connect` command which talks to the Rest API of the kafka-connect instance.
Used by `django_kafka.connect.connector.Connector` to initialize `django_kafka.connect.client.KafkaConnectClient`.
## Suppressing producers:
`django-kafka` provides two ways to suppress producers:
### `producer.suppress`
Use the `producer.suppress` decorator and context manager to suppress the producing of messages generated by the `Producer` class during a particular context.
```python
from django_kafka import producer
@producer.suppress(["topic1"]) # suppress producers to topic1
def my_function():
...
def my_function_two():
with producer.suppress(["topic1"]): # suppress producers to topic1
...
```
`producer.suppress` can take a list of topic names, or no arguments to suppress producers of all topics.
Use `producer.unsuppress` to deactivate any set suppression during a specific context.
### `KafkaConnectSkipModel.kafka_skip`
Pythonic suppression methods will not suffice when using Kafka Connect to directly produce events from database changes. In this scenario, it's more appropriate to add a flag to the model database table which indicates if the connector should generate an event. Two classes are provided subclassing Django's Model and QuerySet to manage this flag:
#### KafkaConnectSkipModel
Adds the `kafka_skip` boolean field, defaulting to `False`. This also automatically resets `kafka_skip` to `False` when saving instances (if not explicitly set).
Usage:
```python
from django.contrib.auth.base_user import AbstractBaseUser
from django.contrib.auth.models import PermissionsMixin
from django_kafka.connect.models import KafkaConnectSkipModel
class User(KafkaConnectSkipModel, PermissionsMixin, AbstractBaseUser):
# ...
```
#### KafkaConnectSkipQueryset
If you have defined a custom manager on your model then you should inherit it from `KafkaConnectSkipQueryset`. It adds `kafka_skip=False` when using the `update` method.
**Note:** `kafka_skip=False` is only set when it's not provided to the `update` kwargs. E.g. `User.objects.update(first_name="John", kafka_skip=True)` will not be changed to `kafka_skip=False`.
Usage:
```python
from django.contrib.auth.base_user import AbstractBaseUser
from django.contrib.auth.base_user import BaseUserManager
from django.contrib.auth.models import PermissionsMixin
from django_kafka.connect.models import KafkaConnectSkipModel, KafkaConnectSkipQueryset
class UserManager(BaseUserManager.from_queryset(KafkaConnectSkipQueryset)):
# ...
class User(KafkaConnectSkipModel, PermissionsMixin, AbstractBaseUser):
# ...
objects = UserManager()
```
## Bidirectional data sync with no infinite event loop:
**For example, you want to keep a User table in sync in multiple systems.**
### Infinite loop
You are likely to encounter infinite message generation when syncing data between multiple systems. Message suppression helps overcome this issue.
For purely pythonic producers and consumers, the `produce.suppress` decorator can be used to suppress messages produced during consumption. If you wish to do this globally for all consuming, use the decorator in your `Consumer` class:
```python
from django_kafka import producer
from django_kafka.consumer import Consumer
class MyConsumer(Consumer):
@producer.suppress
def consume(self, *args, **kwargs):
super().consume(*args, **kwargs)
```
When producing with Kafka Connect, the `KafkaConnectSkipModel` provides the `kafka_skip` flag; the record should be manually marked with `kafka_skip=True` at consumption time and the connector should be configured not to send events when this flag is set.
### Global message ordering
To maintain global message ordering between systems, all events for the same database table should be sent to the same topic. The disadvantage is that each system will still consume its own message.
## Making a new release
- [bump-my-version](https://github.com/callowayproject/bump-my-version) is used to manage releases.
- [Ruff](https://github.com/astral-sh/ruff) linter is used to validate the code style. Make sure your code complies withg the defined rules. You may use `ruff check --fix` for that. Ruff is executed by GitHub actions and the workflow will fail if Ruff validation fails.
- Add your changes to the [CHANGELOG](CHANGELOG.md), then run
```bash
docker compose run --rm app bump-my-version bump <major|minor|patch>
```
This will update version major/minor/patch version respectively and add a tag for release.
- Once the changes are approved and merged, push the tag to publish the release to pypi.
```bash
git push origin tag <tag_name>
```
Raw data
{
"_id": null,
"home_page": null,
"name": "django-kafka",
"maintainer": null,
"docs_url": null,
"requires_python": ">=3.11",
"maintainer_email": null,
"keywords": "django, kafka",
"author": null,
"author_email": "RegioHelden GmbH <opensource@regiohelden.de>",
"download_url": "https://files.pythonhosted.org/packages/fb/a4/67cb3695b663be8653e52dc309d2bbf15ba7b742f40ab368cce393c128eb/django_kafka-0.5.9.tar.gz",
"platform": null,
"description": "# django-kafka\nThis library is using [confluent-kafka-python](https://github.com/confluentinc/confluent-kafka-python) which is a wrapper around the [librdkafka](https://github.com/confluentinc/librdkafka) (Apache Kafka C/C++ client library).\n\nIt helps to integrate kafka with Django. \n\n## Quick start\n\n```bash\npip install django-kafka\n```\n\n### Configure:\nConsidering you have locally setup kafka instance with no authentication. All you need is to define the bootstrap servers.\n```python\n# ./settings.py\n\nINSTALLED_APPS = [\n # ...\n \"django_kafka\",\n]\n\nDJANGO_KAFKA = {\n \"GLOBAL_CONFIG\": {\n \"bootstrap.servers\": \"kafka1:9092\",\n },\n}\n```\n\n### Define a Topic:\n\nTopics define how to handle incoming messages and how to produce an outgoing message.\n```python\nfrom confluent_kafka.serialization import MessageField\nfrom django_kafka.topic import Topic\n\n\nclass Topic1(Topic):\n name = \"topic1\"\n\n def consume(self, msg):\n key = self.deserialize(msg.key(), MessageField.KEY, msg.headers())\n value = self.deserialize(msg.value(), MessageField.VALUE, msg.headers())\n # ... process values\n```\n\n`Topic` inherits from the `TopicProducer` and `TopicConsumer` classes. If you only need to consume or produce messages, inherit from one of these classes instead to avoid defining unnecessary abstract methods. \n\n### Define a Consumer:\n\nConsumers define which topics they take care of. Usually you want one consumer per project. If 2 consumers are defined, then they will be started in parallel.\n\nConsumers are auto-discovered and are expected to be located under the `some_django_app/kafka/consumers.py` or `some_django_app/consumers.py`.\n\n```python\n# ./consumers.py\n\nfrom django_kafka import kafka\nfrom django_kafka.consumer import Consumer, Topics\n\nfrom my_app.topics import Topic1\n\n\n# register your consumer using `DjangoKafka` class API decorator\n@kafka.consumers()\nclass MyAppConsumer(Consumer):\n # tell the consumers which topics to process using `django_kafka.consumer.Topics` interface.\n topics = Topics(\n Topic1(),\n )\n\n config = {\n \"group.id\": \"my-app-consumer\",\n \"auto.offset.reset\": \"latest\",\n \"enable.auto.offset.store\": False,\n }\n```\n\n\n### Start the Consumers:\nYou can use django management command to start defined consumers.\n```bash\n./manage.py kafka_consume\n```\nOr you can use `DjangoKafka` class API.\n```python\nfrom django_kafka import kafka\n\nkafka.run_consumers()\n```\nCheck [Confluent Python Consumer](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#consumer) for API documentation.\n\n\n\n### Produce:\nMessage are produced using a Topic instance.\n```python\nfrom my_app.topics import Topic1\n\n# this will send a message to kafka, serializing it using the defined serializer \nTopic1().produce(\"some message\")\n```\nCheck [Confluent Python Producer](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#producer) for API documentation.\n\n\n### Define schema registry:\n\nThe library is using [Confluent's SchemaRegistryClient](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#schemaregistryclient). In order to use it define a `SCHEMA_REGISTRY` setting. \n\nFind available configs in the [SchemaRegistryClient docs](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#schemaregistryclient).\n```python\nDJANGO_KAFKA = {\n \"SCHEMA_REGISTRY\": {\n \"url\": \"http://schema-registry\",\n },\n}\n```\n\n**Note:** take [django_kafka.topic.AvroTopic](./django_kafka/topic.py) as an example if you want to implement a custom Topic with your schema.\n\n## Specialized Topics:\n\n### ModelTopicConsumer:\n\n`ModelTopicConsumer` can be used to sync django model instances from abstract kafka events. Simply inherit the class, set the model, the topic to consume from and define a few abstract methods.\n\n```py\n\nfrom django_kafka.topic.model import ModelTopicConsumer\n\nfrom my_app.models import MyModel\n\nclass MyModelConsumer(ModelTopicConsumer):\n name = \"topic\"\n model = MyModel\n\n def is_deletion(self, model, key, value) -> bool:\n \"\"\"returns if the message represents a deletion\"\"\"\n return value.pop('__deleted', False)\n \n def get_lookup_kwargs(self, model, key, value) -> dict:\n \"\"\"returns the lookup kwargs used for filtering the model instance\"\"\"\n return {\"id\": key}\n```\n\nModel instances will have their attributes synced from the message value. If you need to alter a message key or value before it is assigned, define a `transform_{attr}` method:\n\n```python\n\n class MyModelConsumer(ModelTopicConsumer):\n ...\n def transform_name(model, key, value):\n return 'first_name', value[\"name\"].upper()\n```\n\n### DbzModelTopicConsumer:\n\n`DbzModelTopicConsumer` helps sync model instances from [debezium source connector](https://debezium.io/documentation/reference/stable/architecture.html) topics. It inherits from `ModelTopicConsumer` and defines default implementations for `is_deletion` and `get_lookup_kwargs` methods.\n\nIn Debezium it is possible to [reroute records](https://debezium.io/documentation/reference/stable/transformations/topic-routing.html) from multiple sources to the same topic. In doing so Debezium [inserts a table identifier](https://debezium.io/documentation/reference/stable/transformations/topic-routing.html#_ensure_unique_key) to the key to ensure uniqueness. When this key is inserted, you **must instead** define a `reroute_model_map` to map the table identifier to the model class to be created.\n\n```py\n\nfrom django_kafka.topic.debezium import DbzModelTopicConsumer\n\nfrom my_app.models import MyModel, MyOtherModel\n\nclass MyModelConsumer(DbzModelTopicConsumer):\n name = \"debezium_topic\"\n reroute_model_map = {\n 'public.my_model': MyModel,\n 'public.my_other_model': MyOtherModel,\n }\n```\n\nA few notes:\n\n1. The connector must be using the [event flattening SMT](https://debezium.io/documentation/reference/stable/transformations/event-flattening.html) to simplify the message structure.\n2. [Deletions](https://debezium.io/documentation/reference/stable/transformations/event-flattening.html#extract-new-record-state-delete-tombstone-handling-mode) are detected automatically based on a null message value or the presence of a `__deleted` field.\n3. The message key is assumed to contain the model PK as a field, [which is the default behaviour](https://debezium.io/documentation/reference/stable/connectors/postgresql.html#postgresql-property-message-key-columns) for Debezium source connectors. If you need more complicated lookup behaviour, override `get_lookup_kwargs`.\n\n## Dead Letter Topic:\n\nAny message which fails to consume will be sent to the dead letter topic. The dead letter topic name is combined of the consumer group id, the original topic name, and a `.dlt` suffix (controllable with the `DEAD_LETTER_TOPIC_SUFFIX` setting). So for a failed message in `topic` received by consumer `group`, the dead letter topic name would be `group.topic.dlt`.\n\n## Retries:\n\nAdd retry behaviour to a topic by using the `retry` decorator:\n\n```python\nfrom django_kafka import kafka\nfrom django_kafka.topic import Topic\n\n\n@kafka.retry(max_retries=3, delay=120, include=[ValueError])\nclass RetryableTopic(Topic):\n name = \"topic\"\n ...\n```\n\nYou can also configure retry behaviour globally for all topics with the `RETRY_SETTINGS` configuration (see [settings](#settings)).\n\nRetries can be either blocking or non-blocking, controlled by the `blocking` boolean parameter. By default, all retries are blocking. \n\n### Blocking Retries:\n\nWhen the consumption of a message fails in a blocking retryable topic, the consumer process will pause the partition and retry the message at a later time. Therefore, messages in that partition will be blocked until the failing message succeeds or the maximum retry attempts are reached, after which the message is sent to the dead letter topic.\n\n### Non-blocking Retries:\n\nWhen the consumption of a message fails in a non-blocking retryable topic, the message is re-sent to a topic with a name combined of the consumer group id, the original topic name, a `.retry` suffix (controllable with the `RETRY_TOPIC_SUFFIX` setting), and the retry number. Subsequent failed retries will then be sent to retry topics of incrementing retry number until the maximum attempts are reached, after which it will be sent to a dead letter topic. So for a failed message in topic `topic`, with a maximum retry attempts of 3 and received by consumer group `group`, the expected topic sequence would be: \n\n1. `topic`\n2. `group.topic.retry.1`\n3. `group.topic.retry.2`\n4. `group.topic.retry.3`\n5. `group.topic.dlt`\n\nWhen consumers are started using [start commands](#start-the-Consumers), an additional retry consumer will be started in parallel for any consumer containing a non-blocking retryable topic. This retry consumer will be assigned to a consumer group whose id is a combination of the original group id and a `.retry` suffix. This consumer is subscribed to the retry topics, and manages the message retry and delay behaviour. Please note that messages are retried directly by the retry consumer and are not sent back to the original topic.\n\n## Connectors:\n\nConnectors are auto-discovered and are expected to be located under the `some_django_app/kafka/connectors.py` or `some_django_app/connectors.py`.\n\nConnectors are defined as python classes decorated with `@kafka.connectors()` which adds the class to the global registry. \n\n`django_kafka.connect.connector.Connector` implements submission, validation and deletion of the connector configuration.\n\n### Define connector:\n```python\n# Connectors are discovered automatically when placed under the connectors module\n# e.g. ./connectors.py\n\nfrom django_kafka import kafka\nfrom django_kafka.connect.connector import Connector\n\n\n@kafka.connectors()\nclass MyConnector(Connector):\n config = {\n # configuration for the connector\n }\n```\n\n### Mark a connector for removal:\n\n```python\nfrom django_kafka import kafka\nfrom django_kafka.connect.connector import Connector\n\n\n@kafka.connectors()\nclass MyConnector(Connector):\n mark_for_removal = True\n config = {\n # configuration for the connector\n }\n```\n\n### Manage connectors:\n\ndjango-kafka provides `./manage.py kafka_connect` management command to manage your connectors.\n\n\n#### Manage a single connector\n```bash\n./manage.py kafka_connect path.to.my.SpecialConnector --validate --publish --check-status --ignore-failures\n````\n\n#### Manage all connectors\n```bash\n./manage.py kafka_connect --validate --publish --check-status --ignore-failures\n````\n\n`--validate` - validates the config over the connect REST API\n\n`--publish` - create or update the connector or delete when `mark_for_removal = True`\n\n`--check-status` - check the status of the connector is `RUNNING`.\n\n`--ignore-failures` - command wont fail if any of the connectors fail to validate or publish.\n\nSee `--help`.\n\n## Settings:\n\n**Defaults:**\n```python\nDJANGO_KAFKA = {\n \"CLIENT_ID\": f\"{socket.gethostname()}-python\",\n \"ERROR_HANDLER\": \"django_kafka.error_handlers.ClientErrorHandler\",\n \"GLOBAL_CONFIG\": {},\n \"PRODUCER_CONFIG\": {},\n \"CONSUMER_CONFIG\": {},\n \"RETRY_CONSUMER_CONFIG\": {\n \"auto.offset.reset\": \"earliest\",\n \"enable.auto.offset.store\": False,\n \"topic.metadata.refresh.interval.ms\": 10000,\n },\n \"RETRY_SETTINGS\": None,\n \"RETRY_TOPIC_SUFFIX\": \"retry\",\n \"DEAD_LETTER_TOPIC_SUFFIX\": \"dlt\",\n \"POLLING_FREQUENCY\": 1, # seconds\n \"SCHEMA_REGISTRY\": {},\n # Rest API of the kafka-connect instance\n \"CONNECT_HOST\": None,\n # `requests.auth.AuthBase` instance or tuple of (username, password) for Basic Auth\n \"CONNECT_AUTH\": None,\n # kwargs for `urllib3.util.retry.Retry` initialization\n \"CONNECT_RETRY\": dict(\n connect=5,\n read=5,\n status=5,\n backoff_factor=0.5,\n status_forcelist=[502, 503, 504],\n ),\n # `django_kafka.connect.client.KafkaConnectSession` would pass this value to every request method call\n \"CONNECT_REQUESTS_TIMEOUT\": 30,\n \"CONNECTOR_NAME_PREFIX\": \"\",\n}\n```\n\n#### `CLIENT_ID`\nDefault: `f\"{socket.gethostname()}-python\"`\n\nAn id string to pass to the server when making requests. The purpose of this is to be able to track the source of requests beyond just ip/port by allowing a logical application name to be included in server-side request logging.\n\n**Note:** This parameter is included in the config of both the consumer and producer unless `client.id` is overwritten within `PRODUCER_CONFIG` or `CONSUMER_CONFIG`.\n\n#### `GLOBAL_CONFIG`\nDefault: `{}`\n\nDefines configurations applied to both consumer and producer. See [configs marked with `*`](https://github.com/confluentinc/librdkafka/blob/master/CONFIGURATION.md).\n\n#### `PRODUCER_CONFIG`\nDefault: `{}`\n\nDefines configurations of the producer. See [configs marked with `P`](https://github.com/confluentinc/librdkafka/blob/master/CONFIGURATION.md).\n\n#### `CONSUMER_CONFIG`\nDefault: `{}`\n\nDefines configurations of the consumer. See [configs marked with `C`](https://github.com/confluentinc/librdkafka/blob/master/CONFIGURATION.md).\n\n#### `RETRY_CONSUMER_CONFIG`\nDefault:\n\n```py\n{\n \"auto.offset.reset\": \"earliest\",\n \"enable.auto.offset.store\": False,\n \"topic.metadata.refresh.interval.ms\": 10000,\n}\n```\n\nDefines configuration for the retry consumer. See [Non-blocking retries](#non-blocking-retries).\n\n#### `RETRY_TOPIC_SUFFIX`\nDefault: `retry`\n\nDefines the retry topic suffix. See [Non-blocking retries](#non-blocking-retries).\n\n#### `RETRY_SETTINGS`\nDefault: `None`\n\nDefines the default retry settings. See [retries](#retries).\n\n#### `DEAD_LETTER_TOPIC_SUFFIX`\nDefault: `dlt`\n\nDefines the dead letter topic suffix. See [Dead Letter Topic](#dead-letter-topic).\n\n#### `POLLING_FREQUENCY`\nDefault: 1 # second\n\nHow often client polls for events.\n\n#### `SCHEMA_REGISTRY`\nDefault: `{}`\n\nConfiguration for [confluent_kafka.schema_registry.SchemaRegistryClient](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#schemaregistryclient).\n\n#### `ERROR_HANDLER`\nDefault: `django_kafka.error_handlers.ClientErrorHandler`\n\nThis is an `error_cb` hook (see [Kafka Client Configuration](https://docs.confluent.io/platform/current/clients/confluent-kafka-python/html/index.html#kafka-client-configuration) for reference).\nIt is triggered for client global errors and in case of fatal error it raises `DjangoKafkaError`.\n\n#### `CONNECT_HOST`\nDefault: `None`\n\nRest API of the kafka-connect instance.\n\n#### `CONNECT_AUTH`\nDefault: `None`\n\n`requests.auth.AuthBase` instance or `(\"username\", \"password\")` for Basic Auth.\n\n#### `CONNECT_AUTH`\nDefault: `dict(\n connect=5,\n read=5,\n status=5,\n backoff_factor=0.5,\n status_forcelist=[502, 503, 504],\n)`\n\nkwargs for `urllib3.util.retry.Retry` initialization.\n\n#### `CONNECT_REQUESTS_TIMEOUT`\nDefault: `30`\n\n`django_kafka.connect.client.KafkaConnectSession` would pass this value to every request method call.\n\n#### `CONNECTOR_NAME_PREFIX`\nDefault: `\"\"`\n\nPrefix which will be added to the connector name when publishing the connector. \n\n`CONNECT_` settings are required for `./manage.py kafka_connect` command which talks to the Rest API of the kafka-connect instance.\n\nUsed by `django_kafka.connect.connector.Connector` to initialize `django_kafka.connect.client.KafkaConnectClient`.\n\n\n## Suppressing producers:\n\n`django-kafka` provides two ways to suppress producers:\n\n### `producer.suppress`\n\nUse the `producer.suppress` decorator and context manager to suppress the producing of messages generated by the `Producer` class during a particular context.\n\n```python\nfrom django_kafka import producer\n\n\n@producer.suppress([\"topic1\"]) # suppress producers to topic1\ndef my_function():\n ...\n\n\ndef my_function_two():\n with producer.suppress([\"topic1\"]): # suppress producers to topic1\n ...\n```\n\n`producer.suppress` can take a list of topic names, or no arguments to suppress producers of all topics. \n\nUse `producer.unsuppress` to deactivate any set suppression during a specific context.\n\n\n### `KafkaConnectSkipModel.kafka_skip`\n\nPythonic suppression methods will not suffice when using Kafka Connect to directly produce events from database changes. In this scenario, it's more appropriate to add a flag to the model database table which indicates if the connector should generate an event. Two classes are provided subclassing Django's Model and QuerySet to manage this flag:\n\n#### KafkaConnectSkipModel\nAdds the `kafka_skip` boolean field, defaulting to `False`. This also automatically resets `kafka_skip` to `False` when saving instances (if not explicitly set).\n\nUsage:\n\n```python\nfrom django.contrib.auth.base_user import AbstractBaseUser\nfrom django.contrib.auth.models import PermissionsMixin\nfrom django_kafka.connect.models import KafkaConnectSkipModel\n\n\nclass User(KafkaConnectSkipModel, PermissionsMixin, AbstractBaseUser):\n # ...\n```\n\n\n#### KafkaConnectSkipQueryset\nIf you have defined a custom manager on your model then you should inherit it from `KafkaConnectSkipQueryset`. It adds `kafka_skip=False` when using the `update` method.\n\n**Note:** `kafka_skip=False` is only set when it's not provided to the `update` kwargs. E.g. `User.objects.update(first_name=\"John\", kafka_skip=True)` will not be changed to `kafka_skip=False`.\n\nUsage:\n\n```python\nfrom django.contrib.auth.base_user import AbstractBaseUser\nfrom django.contrib.auth.base_user import BaseUserManager\nfrom django.contrib.auth.models import PermissionsMixin\nfrom django_kafka.connect.models import KafkaConnectSkipModel, KafkaConnectSkipQueryset\n\n\nclass UserManager(BaseUserManager.from_queryset(KafkaConnectSkipQueryset)):\n\n\n# ...\n\n\nclass User(KafkaConnectSkipModel, PermissionsMixin, AbstractBaseUser):\n # ...\n objects = UserManager()\n```\n\n## Bidirectional data sync with no infinite event loop:\n\n**For example, you want to keep a User table in sync in multiple systems.**\n\n### Infinite loop\n\nYou are likely to encounter infinite message generation when syncing data between multiple systems. Message suppression helps overcome this issue.\n\nFor purely pythonic producers and consumers, the `produce.suppress` decorator can be used to suppress messages produced during consumption. If you wish to do this globally for all consuming, use the decorator in your `Consumer` class:\n\n```python\nfrom django_kafka import producer\nfrom django_kafka.consumer import Consumer\n\nclass MyConsumer(Consumer):\n \n @producer.suppress\n def consume(self, *args, **kwargs):\n super().consume(*args, **kwargs)\n```\n\nWhen producing with Kafka Connect, the `KafkaConnectSkipModel` provides the `kafka_skip` flag; the record should be manually marked with `kafka_skip=True` at consumption time and the connector should be configured not to send events when this flag is set.\n\n### Global message ordering\n\nTo maintain global message ordering between systems, all events for the same database table should be sent to the same topic. The disadvantage is that each system will still consume its own message. \n\n\n## Making a new release\n- [bump-my-version](https://github.com/callowayproject/bump-my-version) is used to manage releases.\n- [Ruff](https://github.com/astral-sh/ruff) linter is used to validate the code style. Make sure your code complies withg the defined rules. You may use `ruff check --fix` for that. Ruff is executed by GitHub actions and the workflow will fail if Ruff validation fails. \n\n- Add your changes to the [CHANGELOG](CHANGELOG.md), then run\n```bash\ndocker compose run --rm app bump-my-version bump <major|minor|patch>\n```\nThis will update version major/minor/patch version respectively and add a tag for release.\n\n- Once the changes are approved and merged, push the tag to publish the release to pypi.\n```bash\ngit push origin tag <tag_name>\n```\n",
"bugtrack_url": null,
"license": "Copyright 2024 RegioHelden GmbH Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation files (the \"Software\u201d), to deal in the Software without restriction, including without limitation the rights to use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the Software is furnished to do so, subject to the following conditions: The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software. THE SOFTWARE IS PROVIDED \"AS IS\u201d, WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE. ",
"summary": "Confluent's Kafka Python Client combined with Django",
"version": "0.5.9",
"project_urls": {
"Changelog": "https://github.com/RegioHelden/django-kafka/blob/main/CHANGELOG.md",
"Issues": "https://github.com/RegioHelden/django-kafka/issues",
"Repository": "https://github.com/RegioHelden/django-kafka"
},
"split_keywords": [
"django",
" kafka"
],
"urls": [
{
"comment_text": "",
"digests": {
"blake2b_256": "2e5d80d39bc39313e34426f5ead5e4e0e01cc3f0f481023c78c2a0044275a1a9",
"md5": "408af4f8897ce96dc6d048a4d9012e78",
"sha256": "d8025bb1836c89f60b77df003a7c4eb7c2493ccdaa0684cacdf314ca37f8500d"
},
"downloads": -1,
"filename": "django_kafka-0.5.9-py3-none-any.whl",
"has_sig": false,
"md5_digest": "408af4f8897ce96dc6d048a4d9012e78",
"packagetype": "bdist_wheel",
"python_version": "py3",
"requires_python": ">=3.11",
"size": 63467,
"upload_time": "2024-11-28T15:23:59",
"upload_time_iso_8601": "2024-11-28T15:23:59.724708Z",
"url": "https://files.pythonhosted.org/packages/2e/5d/80d39bc39313e34426f5ead5e4e0e01cc3f0f481023c78c2a0044275a1a9/django_kafka-0.5.9-py3-none-any.whl",
"yanked": false,
"yanked_reason": null
},
{
"comment_text": "",
"digests": {
"blake2b_256": "fba467cb3695b663be8653e52dc309d2bbf15ba7b742f40ab368cce393c128eb",
"md5": "9398a6b93d49dbdf7f59a723947eea0b",
"sha256": "7c775a06b67a3b74210123db35ed3dc53281f5bd9884ea07d46e4697a5100675"
},
"downloads": -1,
"filename": "django_kafka-0.5.9.tar.gz",
"has_sig": false,
"md5_digest": "9398a6b93d49dbdf7f59a723947eea0b",
"packagetype": "sdist",
"python_version": "source",
"requires_python": ">=3.11",
"size": 49420,
"upload_time": "2024-11-28T15:24:01",
"upload_time_iso_8601": "2024-11-28T15:24:01.439533Z",
"url": "https://files.pythonhosted.org/packages/fb/a4/67cb3695b663be8653e52dc309d2bbf15ba7b742f40ab368cce393c128eb/django_kafka-0.5.9.tar.gz",
"yanked": false,
"yanked_reason": null
}
],
"upload_time": "2024-11-28 15:24:01",
"github": true,
"gitlab": false,
"bitbucket": false,
"codeberg": false,
"github_user": "RegioHelden",
"github_project": "django-kafka",
"travis_ci": false,
"coveralls": false,
"github_actions": true,
"lcname": "django-kafka"
}