-
Notifications
You must be signed in to change notification settings - Fork 589
Commit
This commit does not belong to any branch on this repository, and may belong to a fork outside of the repository.
redpanda_oauth_test: Stub test for OIDC support
- Spins up a redpanda cluster and a KeycloakService - Creates a user under the demo realm, with realm-admin priv - Registers a client with keycloak - Update client's service account to include an email address - This will appear in the access token as the grant includes the 'email' scope. - Initializes PythonLibrdkafka with appropriate info (client ID, secret) - Sends some messages (this will fail without backend support)
- Loading branch information
Showing
1 changed file
with
150 additions
and
0 deletions.
There are no files selected for viewing
This file contains bidirectional Unicode text that may be interpreted or compiled differently than what appears below. To review, open the file in an editor that reveals hidden Unicode characters.
Learn more about bidirectional Unicode characters
Original file line number | Diff line number | Diff line change |
---|---|---|
@@ -0,0 +1,150 @@ | ||
# Copyright 2023 Redpanda Data, Inc. | ||
# | ||
# Use of this software is governed by the Business Source License | ||
# included in the file licenses/BSL.md | ||
# | ||
# As of the Change Date specified in that file, in accordance with | ||
# the Business Source License, use of this software will be governed | ||
# by the Apache License, Version 2.0 | ||
|
||
import time | ||
import functools | ||
import json | ||
|
||
from rptest.clients.python_librdkafka import PythonLibrdkafka | ||
from rptest.clients.types import TopicSpec | ||
from rptest.services.redpanda import LoggingConfig, RedpandaService, SecurityConfig, make_redpanda_service | ||
from rptest.services.keycloak import KeycloakService | ||
from rptest.services.cluster import cluster | ||
|
||
from ducktape.tests.test import Test | ||
from rptest.services.redpanda import make_redpanda_service | ||
from rptest.clients.rpk import RpkTool | ||
from rptest.util import expect_exception | ||
|
||
from confluent_kafka import KafkaException | ||
|
||
CLIENT_ID = 'myapp' | ||
|
||
|
||
class RedpandaOIDCTestBase(Test): | ||
""" | ||
Base class for tests that use the Redpanda service with OIDC | ||
""" | ||
def __init__(self, | ||
test_context, | ||
num_nodes=5, | ||
sasl_mechanisms=['SCRAM', 'OAUTHBEARER'], | ||
**kwargs): | ||
super(RedpandaOIDCTestBase, self).__init__(test_context, **kwargs) | ||
self.produce_messages = [] | ||
self.produce_errors = [] | ||
num_brokers = num_nodes - 1 | ||
self.keycloak = KeycloakService(test_context) | ||
|
||
security = SecurityConfig() | ||
security.enable_sasl = True | ||
security.sasl_mechanisms = sasl_mechanisms | ||
|
||
self.redpanda = make_redpanda_service(test_context, num_brokers) | ||
self.redpanda.set_security_settings(security) | ||
|
||
self.rpk = RpkTool(self.redpanda, | ||
username='admin', | ||
password='admin', | ||
sasl_mechanism="SCRAM-SHA-256") | ||
|
||
def delivery_report(self, err, msg): | ||
""" | ||
Reports the failure or success of a message delivery. | ||
Successfully delivered messages are placed in `messages`. | ||
Errors are placed in `errors` | ||
Args: | ||
err (KafkaError): The error that occurred on None on success. | ||
msg (Message): The message that was produced or failed. | ||
""" | ||
if err is not None: | ||
self.produce_errors.append( | ||
'Delivery failed for User record {}: {}'.format( | ||
msg.key(), err)) | ||
return | ||
self.produce_messages.append( | ||
'User record {} successfully produced to {} [{}] at offset {}'. | ||
format(msg.key(), msg.topic(), msg.partition(), msg.offset())) | ||
|
||
def setUp(self): | ||
self.produce_messages.clear() | ||
self.produce_errors.clear() | ||
self.redpanda.logger.info("Starting Redpanda") | ||
self.redpanda.start() | ||
|
||
|
||
class RedpandaOIDCTest(RedpandaOIDCTestBase): | ||
@cluster(num_nodes=5) | ||
def test_init(self): | ||
kc_node = self.keycloak.nodes[0] | ||
try: | ||
self.keycloak.start_node(kc_node) | ||
except Exception as e: | ||
self.logger.error(f"{e}") | ||
self.keycloak.clean_node(kc_node) | ||
assert False, "Keycloak failed to start" | ||
|
||
self.rpk.create_topic('foo') | ||
|
||
self.keycloak.admin.create_user('norma', | ||
'desmond', | ||
realm_admin=True, | ||
email='[email protected]') | ||
self.keycloak.login_admin_user(kc_node, 'norma', 'desmond') | ||
self.keycloak.admin.create_client(CLIENT_ID) | ||
|
||
# add an email address to myapp client's service user. this should | ||
# appear alongside the access token. | ||
self.keycloak.admin.update_user(f'service-account-{CLIENT_ID}', | ||
email='[email protected]') | ||
|
||
cfg = self.keycloak.generate_oauth_config(kc_node, CLIENT_ID) | ||
assert cfg.client_secret is not None | ||
assert cfg.token_endpoint is not None | ||
k_client = PythonLibrdkafka(self.redpanda, | ||
algorithm='OAUTHBEARER', | ||
oauth_config=cfg) | ||
producer = k_client.get_producer() | ||
|
||
producer.produce(topic='foo', | ||
key='bar', | ||
value='23', | ||
on_delivery=self.delivery_report) | ||
producer.produce(topic='foo', | ||
key='baz', | ||
value='23', | ||
on_delivery=self.delivery_report) | ||
producer.produce(topic='foo', | ||
key='qux', | ||
value='23', | ||
on_delivery=self.delivery_report) | ||
|
||
# Expclicit poll triggers OIDC token flow. Required for librdkafka | ||
# metadata requests to behave nicely. | ||
producer.poll(0.0) | ||
|
||
with expect_exception(KafkaException, lambda _: True): | ||
producer.list_topics(timeout=5) | ||
|
||
self.logger.info('Flushing {} records...'.format(len(producer))) | ||
|
||
# Without the OIDC PoC, Producer.flush raises an AttributeError for some | ||
# reason (rather than just failing). With OIDC support in place, this works | ||
# as expected. | ||
# TODO: Remove Me | ||
with expect_exception(AttributeError, lambda _: True): | ||
producer.flush() | ||
|
||
self.logger.debug(f"{self.produce_messages} {self.produce_errors}") | ||
# assert len(self.produce_messages) == 3, f"Expected 3 messages, got {len(self.produce_messages)}" | ||
# assert len(self.produce_errors) == 0, f"Expected 0 errors, got {len(self.produce_errors)}" | ||
assert True |