Branch | Commit message | Author | Age |
0.10.0.1 | Use new release 0.10.0.1 for 0.10 testing | Dana Powers | 8 years |
0.7 | Making version number compatible with future versions | David Arthur | 12 years |
0.8 | Merge branch 'master' into 0.8 | David Arthur | 12 years |
0.9 | Fix KafkaClient->SimpleClient references | Dana Powers | 9 years |
0_10_1_0 | Update docs | Dana Powers | 8 years |
0_10_1_1 | Switch to 0.10.1.1 | Dana Powers | 8 years |
0_11_0_0 | Do not test fetched_size with fetch_max_bytes since 0.11 brokers will return ... | Dana Powers | 7 years |
0_11_0_1 | Update to 0.11.0.1 for travis test fixture; use as default if unspecified | Dana Powers | 7 years |
0_11_0_2 | Use 0.11.0.2 kafka broker for integration testing | Dana Powers | 7 years |
0_8_2_protocol_parser_too | Revert 703f0659 / fix 0.8.2 protocol quick detection | Dana Powers | 6 years |
1.3.5 | Don't use `kafka.common` internally | Jeff Widman | 6 years |
1.4.7 | Release 1.4.7 | Dana Powers | 5 years |
1193-remove-old-simple-clients | Add a bunch of TODOs | Jeff Widman | 5 years |
1212-stop-using-mutable-types-for-default-arg-values | Stop using mutable types for default arg values | Jeff Widman | 7 years |
1274-producer-raise-non-api-exceptions | Raise non-API exceptions | Jeff Widman | 7 years |
1_0_1 | Add kafka 1.0.1 release to test fixtures | Dana Powers | 7 years |
1_4_0 | Release 1.4.0 | Dana Powers | 7 years |
709 | Protect writes to wakeup socket with threading lock | Dana Powers | 8 years |
741 | Avoid AttributeErrors in _unregister_cleanup | Dana Powers | 8 years |
KAFKA-3117 | KAFKA-3117: handle metadata updates during consumer rebalance | Dana Powers | 8 years |
KAFKA-3196 | KAFKA-3196: Add checksum and size to RecordMetadata and ConsumerRecord | Dana Powers | 8 years |
KAFKA-3197 | KAFKA-3197: when max.in.flight.request.per.connection = 1, attempt to guarant... | Dana Powers | 8 years |
KAFKA-3388 | KAFKA-3388: Fix expiration of batches sitting in the accumulator | Dana Powers | 8 years |
KAFKA-3486 | KAFKA-3486: fix autocommit when partitions assigned manually | Dana Powers | 8 years |
KAFKA-3960 | Fix offset fetch when partitions are manually assigned | Dana Powers | 8 years |
KAFKA-8962-use-least-loaded-node-for-admin-describe-topics | KAFKA-8962: Use least_loaded_node() for describe_topics() | Jeff Widman | 5 years |
KAFKA_3888_heartbeat_thread | Fix lookup future is_done check | Dana Powers | 7 years |
KAFKA_3949_subscription_metadata_race | Dont add commented-out code | Dana Powers | 7 years |
KAFKA_3977_defer_fetch_parsing | More tests | Dana Powers | 7 years |
KAFKA_4034_coordinator_lookup | KAFKA-4034: Avoid unnecessary consumer coordinator lookup | Dana Powers | 7 years |
KAFKA_4160_rebalance_listener_lock | In the middle of kafka.coordinator.consumer | Dana Powers | 7 years |
KAFKA_4160_rebalance_listener_without_lock | KAFKA-4160: Ensure rebalance listener not called with coordinator lock | Dana Powers | 7 years |
KAFKA_5512_notify_heartbeat_thread | KAFKA-5512; Awake the heartbeat thread when timetoNextHeartbeat is equal to 0 | Dana Powers | 7 years |
Remove-deprecated-ConnectionError | Remove deprecated `ConnectionError` | Jeff Widman | 5 years |
Remove-deprecated-smallest-largest | Remove deprecated `'smallest'`/`'largest'` | Jeff Widman | 5 years |
Remove-support-for-api_version-strings | Remove string support in `api_version` | Jeff Widman | 5 years |
Remove-weird-comment-line | Remove unused/weird comment line | Jeff Widman | 5 years |
Stop-shadowing-native-python-ConnectionError-exception | Stop shadowing `ConnectionError` | Jeff Widman | 6 years |
Update-docs-api_version_auto_timeout_ms | Update docs for api_version_auto_timeout_ms | Jeff Widman | 5 years |
absolute_import | Always absolute_import | Dana Powers | 8 years |
accumulator_bugfix | Fix producer threading bug that could crash sender (dict changing during iter... | Dana Powers | 9 years |
add-a-snappy-dose-of-https | Update remote urls: snappy, https, etc | Jeff Widman | 6 years |
add-group-coordinator-lookup | Add group coordinator lookup | Jeff Widman | 6 years |
add-license-to-wheel | Add license to wheel | Jeff Widman | 7 years |
add-list-consumer-groups-offsets | Add list_consumer_group_offsets() | Jeff Widman | 6 years |
add-lz4-and-snappy-to-extras_require | rename to `"zstd"` | Jeff Widman | 4 years |
add-python-37-support | cleanup java install script | Dana Powers | 6 years |
add_makefile | Add build_intergation job for makefile | Taras Voinarovskiy | 7 years |
add_new_api_versions | Add API version determination code for newer kafka brokers | Taras Voinarovskyi | 5 years |
admin_client_unpack_errors | Fix response error checking in KafkaAdminClient send_to_controller | Dana Powers | 6 years |
any_api_version | Do not validate api_version against known versions | Dana Powers | 7 years |
appveyor | Considering appveyor testing for windows | Dana Powers | 7 years |
async_connect_send | Remove sleep check when no partitions assigned -- no longer needed | Dana Powers | 6 years |
async_producer_connect_errors | Cleanup new producer tests... | Dana Powers | 9 years |
async_producer_stop | Producer.stop() now blocks until async thread completes (drop confusing timeo... | Dana Powers | 9 years |
at_exit_weakref | Use weakref when registering a producer.close atexit to fix normal gc | Dana Powers | 8 years |
auth_recv | validate sasl_mechanism against SaslHandShakeResponse enabled_mechanisms | Dana Powers | 7 years |
authenticate_future_handling | Handle blocking socket recv during authentication | Dana Powers | 7 years |
await_reserved | Dont use soon-to-be-reserved keyword await as function name (FutureProduceRes... | Dana Powers | 8 years |
backoff_conn_reconnect | Reset last_attempt in conn connect tests | Dana Powers | 7 years |
backoff_coordinator_retry | Backoff on unavailable group coordinator retry | Dana Powers | 7 years |
batch_expiration_message | Improve error message when expiring batches in KafkaProducer | Dana Powers | 8 years |
batch_size_zero | Support batch_size = 0 in producer buffers | Dana Powers | 9 years |
be-explicit-with-validate_only | Set a clear default value for `validate_only`/`include_synonyms` | Jeff Widman | 6 years |
benchmark_fixups | Fixups to benchmark scripts for py3 / new KafkaFixture interface | Dana Powers | 6 years |
benchmarks | Adapt benchmark scripts from https://github.com/mrafayaleem/kafka-jython | Dana Powers | 8 years |
better-struct-errors | Give better struct errors | Jeff Widman | 7 years |
blackout_timer | Mark last_attempt time during connection close to fix blackout calculation | Dana Powers | 8 years |
bootstrap_cluster | Maintain shadow bootstrap cluster metadata | Dana Powers | 6 years |
bootstrap_cluster_metadata | Do not user bootstrap_topics_filter unless topics is empty | Dana Powers | 6 years |
bootstrap_dns_lookup | Dont check connecting in old simple client | Dana Powers | 7 years |
bootstrap_select | Select on sockets to avoid busy polling during bootstrap | Dana Powers | 7 years |
break-consumer-operations-into-request-response-methods | Break consumer operations into request / response methods | Jeff Widman | 5 years |
break-find-group-coordinator-into-request-response-methods | Break FindCoordinator into request/response methods | Jeff Widman | 5 years |
bump-lz4 | Stop pinning lz4 | Jeff Widman | 7 years |
bump-vendored-six-to-1.11.0 | Bump vendored `six` to `1.11.0` | Jeff Widman | 6 years |
bump_versions | Try to fix pylint issue | Taras Voinarovskyi | 4 years |
cancel_in_flight | When closing a broker connection without error, fail in-flight-requests with ... | Dana Powers | 8 years |
catch_socket_error | Ignore socket.error when checking for protocol out of sync prior to socket close | Dana Powers | 8 years |
check-for-none-in-on-join-complete | Explicitly check for `None` rather than False | Jeff Widman | 7 years |
check-for-none-rather-than-false | Explicitly check for None rather than falsey | Jeff Widman | 7 years |
check_invalid_metadata | Dont refresh metadata on failed group coordinator request unless needed | Dana Powers | 8 years |
check_version | KakfaClient.check_version: Scan all brokers until a version is identified or ... | Dana Powers | 8 years |
check_version_0_10 | Add protocol support for ApiVersionRequest; identify 0.10 brokers in check_ve... | Dana Powers | 9 years |
clean_drain_coordinator_requests | Avoid unknown coordinator after client poll | Dana Powers | 8 years |
cleanup-install-instructions-for-optional-libs | Cleanup install instructions for optional libs | Jeff Widman | 4 years |
cleanup-kafka-admin-test-formatting | Cleanup formatting, no functional changes | Jeff Widman | 6 years |
cleanup-max-bytes-tests | Merge two tests that are very similar | Jeff Widman | 5 years |
cleanup-testing-doc | Minor cleanup of testing doc | Jeff Widman | 6 years |
cleanups | Increase test_producer end-to-end timeouts | Dana Powers | 7 years |
clear_gai_cache | Fixup log format str | Dana Powers | 7 years |
client_api_version | Add api_version config to KafkaClient, deprecate str in favor of tuples | Dana Powers | 8 years |
client_send_race | Avoid race condition on client._conns in send() | Dana Powers | 6 years |
close_consumer_tests | Fix merge conflict | Dana Powers | 7 years |
combine_send_bytes | Send combined size and payload bytes to socket to avoid potentially split pac... | Dana Powers | 8 years |
commit_failed_message_fixup | Remove old CommitFailed error message from coordinator | Dana Powers | 7 years |
compacted_offsets | Use explicit subscription state flag to handle seek() during message iteration | Dana Powers | 8 years |
config_selector | Expose selector type as config option | Dana Powers | 8 years |
conn_check_version_max_in_flight | Monkeypatch max_in_flight_requests_per_connection when checking broker version | Dana Powers | 8 years |
conn_close_short_circuit | Short-circuit BrokerConnection.close() if already disconnected | Dana Powers | 7 years |
conn_delay_ms | Fix BrokerConnection.connection_delay() -- return ms | Dana Powers | 7 years |
conn_immutable_host_port_afi | Make BrokerConnection .host / .port / .afi immutable, use _sock_* attributes ... | Dana Powers | 7 years |
conn_legacy | Delete KafkaConnection class | Dana Powers | 8 years |
conn_lock_async_send | Synchronize puts to KafkaConsumer protocol buffer during async sends | Dana Powers | 6 years |
conn_lock_release_gssapi_oauth | release lock on Exception in oauth | Dana Powers | 5 years |
conn_logging_cleanups | Log connected as INFO | Dana Powers | 7 years |
conn_loop_bytes | Comment indent | Dana Powers | 7 years |
conn_metrics | Instrument bufferpool-wait-ratio metric in KafkaProducer | Dana Powers | 8 years |
conn_metrics_fix | HOTFIX: Fix BrokerConnectionMetrics when sensors already exist (i.e., on reco... | Dana Powers | 8 years |
conn_send_buffer | Always mock selector in KafkaClient tests | Dana Powers | 5 years |
conn_send_timeout | Use socket timeout of request_timeout_ms to prevent blocking forever on send | Dana Powers | 7 years |
conn_state_callback | Add state_change_callback to bootstrap connection | Dana Powers | 9 years |
conn_state_change | Remove close_conns | Dana Powers | 6 years |
connect_blocking | Whitespace cleanup in test_client_async | Dana Powers | 7 years |
connect_blocking_fixups | Only perform single dns lookup for connect_blocking; fix blocking timeout in ... | Dana Powers | 6 years |
connection_delay_inf | Rely on selector to detect completed connection attempts | Dana Powers | 5 years |
connection_error_close | Do not re-close a disconnected connection | Dana Powers | 8 years |
consumer_heartbeat_fixes | Consumer should timeout internal iterator if heartbeat ttl is expired | Dana Powers | 9 years |
consumer_iterator | Revert consumer iterators from max_poll_records | Dana Powers | 8 years |
consumer_iterator_with_poll | Return float(inf) seconds instead of sys.maxsize int in coordinator time to n... | Dana Powers | 5 years |
consumer_poll_sleep | KafkaConsumer.poll should sleep to prevent tight-loops | Dana Powers | 9 years |
consumer_rejoin_fixes | Improve KafkaConsumer join group / only enable Heartbeat Thread during stable... | Dana Powers | 6 years |
convert-remaining-unittests-to-pytest | Bump failing test iterations to 100--is travis happy? | Jeff Widman | 5 years |
coordinator_client_deadlock | Always acquire client lock before coordinator lock to avoid deadlocks | Dana Powers | 7 years |
coordinator_dead_error_logging | Always include an error for logging when the coordinator is marked dead | Dana Powers | 8 years |
coordinator_del | Avoid some exceptions in Coordinator.__del__ | Dana Powers | 9 years |
coordinator_lock_order | Change coordinator lock acquisition order | Dana Powers | 5 years |
coordinator_tests | Add ConsumerCoordinator unit tests | Dana Powers | 9 years |
coordinator_unknown_heartbeat | Log successful heartbeat as INFO; improve heartbeat response logging | Dana Powers | 9 years |
create_topics_v1 | CreateTopicsRequest / Response v1 | Dana Powers | 8 years |
decode_errors | Catch response decode errors and log details | Dana Powers | 8 years |
default_no_consumer_group | Set group_id for testing | Dana Powers | 8 years |
defer_version_check | Defer version check until after bootstrap succeeds | Dana Powers | 7 years |
delay-units-conversion-til-last-possiblepoint | Delay converting to seconds | Jeff Widman | 5 years |
deprecation_warnings | Add DeprecationWarnings to legacy KafkaClient, Simple/MultiProcess/Consumer, ... | Dana Powers | 9 years |
differentiate-between-client-and-broker-version-errors | Differentiate between client and broker version errors | Jeff Widman | 6 years |
disconnects | Improve socket disconnect handling | Dana Powers | 9 years |
docstring-pep8-cleanup | Various docstring / pep8 / code hygiene cleanups | Jeff Widman | 6 years |
document-methods-returning-none | Document methods that return None | Jeff Widman | 6 years |
dont-support-api-version-strings | Remove support for api versions as strings from KafkaAdmin | Jeff Widman | 6 years |
dont-use-broker-errors-for-client-side-problems | Stop using broker-errors for client-side problems | Jeff Widman | 6 years |
dont-use-kafka.common-internally | Don't use `kafka.common` internally | Jeff Widman | 6 years |
double_compression | Fix bug causing KafkaProducer to double-compress message batches on retry | Dana Powers | 8 years |
drain_pending_coordinator_requests | Drain pending requests to the coordinator before initiating group rejoin | Dana Powers | 8 years |
drain_requests_join_group | Fix possible request draining in ensure_active_group | Dana Powers | 8 years |
drop_pytest_sugar | Use latest pytest 3.4.0, but drop pytest-sugar due to incompatibility | Dana Powers | 7 years |
empty_broker_list_metadata | remove unneded import in test_cluster.py | Dana Powers | 6 years |
errors | Cleanup error logging | Dana Powers | 8 years |
except_timeout | Catch TimeoutError in BrokerConnection send/recv | Dana Powers | 5 years |
exclude_internal_topics | Raise error during rebalance if subscribed topics are not authorized | Dana Powers | 8 years |
exp_backoff | Fix conn.connection_delay | Dana Powers | 7 years |
expand-metrics-docs | Use Sphinx warning syntax | Jeff Widman | 7 years |
fast_lookup_coordinator_reset | Update comment | Dana Powers | 7 years |
faster_validate_crc | Avoid re-encoding for message crc check | Dana Powers | 8 years |
fetch | Dont send FetchRequest for (obviously) pending data | Dana Powers | 9 years |
fetch_compacted_offset | Fix PartitionRecords handling of compacted messages | Dana Powers | 7 years |
fetch_partition_compressed_offset | Fix for PartitionRecords has no attribute message_idx; add test | Dana Powers | 7 years |
fetch_poll_backoff | Avoid tight poll loop in consumer when brokers are down | Dana Powers | 7 years |
fetchable_key_error | set.discard is much better | Dana Powers | 7 years |
fetcher_offset_out_of_range | Fix fetcher bug when processing offset out of range | Dana Powers | 8 years |
fetcher_randomize_order | Randomize order of topics/partitions processed by fetcher to improve balance | Dana Powers | 8 years |
fetcher_send_no_wakeup | Do not use wakeup when sending fetch requests from consumer | Dana Powers | 5 years |
finish-bumping-lz4 | Bump `lz4` in `requirements-dev.txt` | Jeff Widman | 7 years |
fix-describe-groups | Fix describe_groups | Jeff Widman | 6 years |
fix-list-groups-to-query-all-brokers | Fix list_consumer_groups() to query all brokers | Jeff Widman | 6 years |
fix-minor-bug-with-printing-bytes-instance | Fix two bugs in printing bytes instance | Andre Araujo | 7 years |
fix-send-to-controller | Fix send to controller | Jeff Widman | 6 years |
fix-sphinx-docs | Fix sphinx bullet points | Jeff Widman | 7 years |
fix-sphinx-url | Fix sphinx url | Jeff Widman | 6 years |
fix-typod-test-file-name | Fix typo in file name | Jeff Widman | 6 years |
fix_close_socket_attribute_error | Fix possible AttribueError during conn._close_socket | Dana Powers | 6 years |
fix_fixture_version_warning | Use test.fixtures.version not test.conftest.version to avoid warnings | Dana Powers | 6 years |
fix_leaks | Dont warn on socket disconnections caused by KafkaClient.close() | Dana Powers | 8 years |
fix_memory_records_typo | Add missed raise in rare case. | Taras | 7 years |
fix_records | Add codec validators to record parser and builder for all formats. | Taras | 7 years |
fix_sasl_reconnect | Fix sasl reconnect bug: auth future must be reset on close | Dana Powers | 8 years |
fix_tests_1_4_7 | Follow up to PR 1782 -- fix tests | Dana Powers | 5 years |
fixture_auto_ports | Dont include kafka.vendor in coverage | Dana Powers | 8 years |
french_connection | Cleanup AF_INET import in conn fixture | Dana Powers | 9 years |
fresh_brokers | Drop old brokers when rebuilding broker metadata | Dana Powers | 8 years |
gc_debug | Log __del__ cleanups | Dana Powers | 6 years |
gen_ssl_resource | Generate SSL certificates for local testing | Dana Powers | 6 years |
get_api_versions_fix | Dont recheck version if api_versions data is already cached | Dana Powers | 6 years |
group_id_none | Disable auto-commit / group assignment in producer test | Dana Powers | 9 years |
gssapi_authentication_complete | Import struct | Dana Powers | 7 years |
handle_api_versions | Add private map of api key -> min/max versions to BrokerConnection | Dana Powers | 7 years |
handle_disconnect | Refresh metadata on failed connection attempts | Dana Powers | 9 years |
heartbeat_cleanups | revert poll timeout change | Dana Powers | 7 years |
heartbeat_logging | Heartbeat thread start / close | Dana Powers | 7 years |
heartbeat_wait_brokers_down | Check for immediate failure when looking up coordinator in heartbeat thread | Dana Powers | 7 years |
hw_crc32c | Add doc notice of optional `crc32c` package | Taras | 7 years |
idle_sleep | Pass consumer timeout to client.poll() in iterator; check timeout before iter... | Dana Powers | 9 years |
initial_metadata_snapshot | Use subscription arg, not self._subscription | Dana Powers | 7 years |
ipv6_scope_id | Connect with sockaddrs to support non-zero ipv6 scope ids | Dana Powers | 7 years |
issue-1082-offset-and-metadata | Optionally return OffsetAndMetadata from consumer.committed(tp) | Dana Powers | 5 years |
issue-1088-full-topic-metadata-skip-error-logging | Do not log topic-specific errors in full metadata fetch | Dana Powers | 5 years |
issue-1219-closed-consumer | StopIteration when consumer closed | Dana Powers | 5 years |
issue-1931-logging-producer-deadlock | Retain blocking on sender thread for del(producer) | Dana Powers | 5 years |
issue-1943-coordinator-node-not-ready-debug | Log retriable coordinator NodeNotReady, TooManyInFlightRequests as debug not ... | Dana Powers | 5 years |
issue-1963-reset-override-configs | Reset conn configs on exception in conn.check_version() | Dana Powers | 5 years |
issue-26 | Starting work on fixing offset commits | David Arthur | 11 years |
issue1036_offset_by_time | Added unit tests for fetcher's `_reset_offset` and related functions. | Taras Voinarovskiy | 7 years |
issue1155 | Make UnknownTopicOrPartitionError retriable error | Taras Voinarovskiy | 7 years |
issue_1399 | Use local copies in Fetcher._fetchable_partitions to avoid mutation errors | Dana Powers | 7 years |
issue_619 | Improve auto-commit task handling when group_id is None | Dana Powers | 9 years |
iterator_fetches | Sleep in KafkaConsumer iterator if no partition assignment; dont block in pol... | Dana Powers | 9 years |
iterator_timeout | Fix internal timeout / sleep handling in consumer iterator | Dana Powers | 9 years |
jeffwidman-patch-1 | No need to cast to list | Jeff Widman | 5 years |
join_future_race | Fix race condition in coordinator join_future handling | Dana Powers | 7 years |
kafka-0.8.0-release | Merge pull request #129 from wizzat/kafka-0.8.0-release | Dana Powers | 11 years |
kafka-2136 | KAFKA-2136: support Fetch and Produce v1 (throttle_time_ms) | Dana Powers | 9 years |
kafka-2978 | KAFKA-2978: consumer stops fetching when consumed and fetch positions get out... | Dana Powers | 9 years |
kafka-3318 | Remove unused imports | Dana Powers | 9 years |
kafka-snake | Scratching on __main__ | Dana Powers | 7 years |
kafka_1_0_0 | Add kafka 1.0.0 to travis integration tests | Dana Powers | 7 years |
kafka_conn_locking_too | Check _can_send_recv with lock to verify state | Dana Powers | 6 years |
kafka_conn_with_lock | fixup var name for consistency | Dana Powers | 5 years |
kafka_error_str | Args are optional in BrokerResponseError str | Dana Powers | 8 years |
kafka_producer | Add KafkaProducer to autodocs and README | Dana Powers | 9 years |
kafka_version_tests | Refactor kafka_versions to support arbitrary operators (> >= < <= ! =) | Dana Powers | 9 years |
larsjsol-sasl_plain | Use callbacks for sasl handshake request / response | Dana Powers | 8 years |
leak_z4 | Alter test skips: python-lz4 works on python26, but not pypy | Dana Powers | 8 years |
least_loaded_node | Update KafkaClient.least_loaded_node | Dana Powers | 8 years |
legacy_records_refactor | Added limit of 100 bytes for Bytes debug prints | Taras Voinarovskiy | 7 years |
lock_client_check_version | lock client.check_version | Dana Powers | 6 years |
log_check_version | Re-enable logging during broker version check | Dana Powers | 7 years |
lower_consumer_timeout | Combine two `poll_ms` defs into one | Jeff Widman | 5 years |
lz4 | Add lz4 to tox environment deps | Dana Powers | 9 years |
lz4_0_10 | Update lz4 codec tests | Dana Powers | 8 years |
lz4_fixup | Handle broken LZ4 framing; switch to lz4tools + xxhash | Dana Powers | 9 years |
master | Allow disabling thread wakeup in send_request_to_node (#2335) | Andrew Zhang | 20 months |
max_poll_records | Fixup iterators | Dana Powers | 8 years |
max_records_int | Validate max_records in KafkaConsumer.poll | Dana Powers | 7 years |
maybe_refreh_metadata_reconnect_delay | Recheck connecting nodes sooner when refreshing metadata | Dana Powers | 6 years |
maybe_refresh_metadata_no_wakeup | Dont wakeup during maybe_refresh_metadata -- it is only called by poll() | Dana Powers | 6 years |
merge-_find_coordinator_ids-methods | Merge _find_coordinator_id methods | Jeff Widman | 4 years |
message_format_v1 | Add some simple message protocol tests | Dana Powers | 8 years |
message_set_encode_size | Always encode size with MessageSet | Dana Powers | 8 years |
metadata_refresh_backoff | Avoid busy poll during metadata refresh failure with retry_backoff_ms | Dana Powers | 8 years |
metadata_v1 | Use MetadataRequest v1 for 0.10+ api_version | Dana Powers | 8 years |
metadata_wait_for_connect | Avoid multiple connection attempts when refreshing metadata | Dana Powers | 8 years |
metadata_with_partitions | Fixup ClusterMetadata __str__ | Dana Powers | 8 years |
migrate-from-unittest-to-pytest | test-this-too | Jeff Widman | 6 years |
minor-exception-cleanup | Minor Exception cleanup | Jeff Widman | 7 years |
mock_dns_test_conn | Mock dns lookups in test_conn | Dana Powers | 6 years |
more_errors | Add new broker response errors | Dana Powers | 8 years |
more_gssapi_fixes | Cleanup gssapi code; fix bug report re AttributeError. | Dana Powers | 7 years |
more_metrics | Add KafkaClient metrics | Dana Powers | 8 years |
more_sasl_fixes | Fix more gssapi errors | Dana Powers | 7 years |
murmur2_ascii | Make DefaultPartitioner importable from kafka.partitioner | Dana Powers | 8 years |
name_node | Include the node id in BrokerConnection __repr__ | Dana Powers | 8 years |
no_ifrs_short_poll | Reduce client poll timeout when no ifrs | Dana Powers | 5 years |
no_sleep | Drop unused sleep kwarg to poll | Dana Powers | 7 years |
no_sleep_til_brooklyn | Wakeup socket optimizations | Dana Powers | 8 years |
node_not_ready | Improve KafkaClient connect and ready handling | Dana Powers | 9 years |
nonblocking_wake_sockets | Use _need_wakeup flag to avoid multiple writes to wake socket | Dana Powers | 6 years |
none_least_loaded_node | Check for None returned from least_loaded_node when no brokers are available | Dana Powers | 9 years |
null_logger | Add logging NullHandler to avoid No Handlers warnings | Dana Powers | 9 years |
old_ssl_exception | Improve SSLWantReadError handling when ssl not available | Dana Powers | 6 years |
partial_messages | Fix bug in MessageSet decoding that crashed multi-partition FetchResponse | Dana Powers | 8 years |
pending_completions | Move callback processing from BrokerConnection to KafkaClient | Dana Powers | 7 years |
pin_deps | Pin pylint and lz4 to avoid breaking tests | Dana Powers | 7 years |
popped_conn_close | Dont treat popped conn.close() as failure in state change callback | Dana Powers | 6 years |
produce_fetch_v2 | Use Fetch/Produce API v2 for brokers >= 0.10 (uses message format v1) | Dana Powers | 8 years |
producer_defaults | Rename _DEFAULT_CONFIG -> DEFAULT_CONFIG in KafkaProducer | Dana Powers | 8 years |
producer_new_topic | Mock client.ensure_topic_exists in test_producer_sync_fail_on_error | Dana Powers | 9 years |
protocol_1_0_0 | Add Request/Response structs for kafka broker 1.0.0 | Dana Powers | 7 years |
protocol_parser | Add kafka.protocol.parser.KafkaProtocol w/ receive and send | Dana Powers | 7 years |
protocol_updates | Cleanup protocol change comments | Dana Powers | 7 years |
protocol_versions | Use version-indexed lists for request/response protocol structs | Dana Powers | 9 years |
pylint_1_8_2 | pylint 1.8.2 | Dana Powers | 7 years |
pylint_fixup | Ignore not-context-manager pylint error | Dana Powers | 8 years |
queue-fixup | Trying to get ReadTheDocs working | David Arthur | 10 years |
range_assignor | Add RangePartitionAssignor (and use as default); add assignor tests | Dana Powers | 9 years |
ready_metadata_kwarg | Add optional kwarg to ready and is_ready to disable metadata-priority logic | Dana Powers | 8 years |
receive_bytes_pipe | BrokerConnection.receive_bytes(data) -> response events | Dana Powers | 7 years |
reconnect_backoff_gai | Only increase reconnect backoff if all addrinfos have been tried | Dana Powers | 7 years |
reconnect_backoff_max_ms_doc_update | Improve docs for reconnect_backoff_max_ms | Dana Powers | 5 years |
record_metadata_simplify | Minor optimization: inline check for no callbacks | Dana Powers | 8 years |
reduce_client_locks | Do not require client lock for read-only operations | Dana Powers | 6 years |
refactor | Add state_change_callback to BrokerConnection | Dana Powers | 9 years |
reference_cleanup_close | Improve KafkaConsumer cleanup | Dana Powers | 7 years |
release | Add changelog to sphinx docs; remove SimpleProducer from API list and move AP... | Dana Powers | 9 years |
release-0.9.x | Trying a different password | David Arthur | 10 years |
remove-pylint-hack | Remove pylint workaround since upstream fixed | Jeff Widman | 3 years |
remove-some-unused-code | Add a bunch of TODOs | Jeff Widman | 5 years |
remove-unused-import | will-this-fix-tests-or-change-to-import-from-conn.dns_lookup? | Jeff Widman | 5 years |
remove-unused-skip_double_compressed_messages | Remove unused `skip_double_compressed_messages` | Jeff Widman | 6 years |
remove_bad_test | Drop bad disconnect test -- just use the mocked-socket test | Dana Powers | 8 years |
request_response_classes | Derive all api classes from Request / Response base classes | Dana Powers | 8 years |
request_timeout_docs | Fix KafkaConsumer docstring for request_timeout_ms default | Dana Powers | 7 years |
reset_reconnect_backoff_connected | Reset reconnect backoff on SSL connection | Dana Powers | 6 years |
return_state_conn_fix | Return connection state explicitly after close in connect() | Dana Powers | 6 years |
revert-1345-heartbeat_cleanups | Revert "Name heartbeat thread with group_id; use backoff when polling (#1345)" | Dana Powers | 7 years |
sansio | protocol notes | Dana Powers | 7 years |
sasl_fixes | Small fixes to SASL documentation and logging; validate security_protocol | Dana Powers | 7 years |
selector_close | Close leaked selector in version check | Dana Powers | 7 years |
selectors | Use selectors module in KafkaClient | Dana Powers | 9 years |
send_first_poll | Send pending requests before waiting for responses | Dana Powers | 6 years |
sender_dont_wakeup | Avoid call to wakeup from sender thread for maybe_connect | Dana Powers | 6 years |
sensor_quota_message | Fix quota violation exception message | Dana Powers | 8 years |
separate_coordinator_conn | sp | Dana Powers | 5 years |
serialize_interface | Add kafka.serializer interfaces | Dana Powers | 8 years |
short_circuit_node_not_ready | Dont prioritize metadata requests over consumer group api calls | Dana Powers | 8 years |
simple | Start test fixtures in new session to avoid propagating signals (i.e., Ctrl-C) | Dana Powers | 9 years |
simple_producer_async_send | Check kwargs for deprecated async option | Dana Powers | 7 years |
simplify-version-checking-using-pytest-skipif | Cleanup handling of KAFKA_VERSION env var in tests | Jeff Widman | 5 years |
six | Vendor six 1.10.0 | Dana Powers | 8 years |
skip_autocommit_consumer_close | Optionally skip auto-commit during consumer.close | Dana Powers | 8 years |
skip_integration_tests | Fix skipped integration tests if KAFKA_VERSION unset | Dana Powers | 7 years |
sock_send_bytes | Handle partial socket send() | Dana Powers | 9 years |
socket_buffer_size_optional | Dont override system rcvbuf or sndbuf unless user configures explicitly | Dana Powers | 9 years |
socket_options | Use socket_options configuration to setsockopts(). Default TCP_NODELAY | Dana Powers | 8 years |
ssl_handshake_errors | Catch socket errors during ssl handshake | Dana Powers | 8 years |
ssl_set_ciphers | Allow configuration of SSL Ciphers | Dana Powers | 6 years |
ssl_support | Attempt to add ssl support to kafka fixtures | Dana Powers | 9 years |
state_change_callback_no_lock_close | Dont call conn.close() with client _lock in state change callback | Dana Powers | 6 years |
stop-pinning-pylint | Stop pinning `pylint` | Jeff Widman | 6 years |
streams | Test streams thingy | Dana Powers | 7 years |
struct-pre-compilation | Pre-compile pack/unpack function calls | billyevans | 6 years |
struct_kwargs | Fix kwarg handing in Struct | Dana Powers | 8 years |
subscription_copy | Return copy of subscription | Dana Powers | 8 years |
task_poll_timeout | Improve KafkaConsumer iterator loop timeouts | Dana Powers | 9 years |
test_cleanups | Minor test cleanups | Dana Powers | 7 years |
testing | Move logging format config to tox.ini to avoid duplicate log capture in pytes... | Dana Powers | 9 years |
threadsafe_pending_responses | Fix pending completion IndexError bug caused by multiple threads | Dana Powers | 7 years |
timeout_idle_connections | Add support for connections_max_idle_ms | Dana Powers | 8 years |
timeout_noresponse | Also/continue to check for timeouts in BrokerConnection.recv() | Dana Powers | 8 years |
timeout_ssl_conn | Timeout all unconnected conns (incl SSL) after request_timeout_ms | Dana Powers | 6 years |
topic_partition_type_error | Raise TypeError in KafkaConsumer when partition is not a TopicPartition | Dana Powers | 9 years |
travis_upgrade | Add py35 to tox testing | Dana Powers | 9 years |
truncate_buffer | Always truncate deallocated produce message buffers | Dana Powers | 9 years |
unrecurse_unpack_message_set | Add skip_double_compressed_messages option to KafkaConsumer | Dana Powers | 8 years |
update-rtd-links | Update RTD links with https / .io | Jeff Widman | 8 years |
use-TypeError | Use TypeError for invalid type | Jeff Widman | 6 years |
use-explicit-tuples-for-strings | Be explicit with tuples for %s formatting | Jeff Widman | 6 years |
use-raw-in-case-string-overriden | Use raw in case string overriden | Jeff Widman | 7 years |
v2_records | Add DefaultRecordBatch implementation aka V2 message format parser/builder. | Taras Voinarovskiy | 7 years |
validate_serialized_bytes | Validate that serializers generate bytes-like (or None) data | Dana Powers | 7 years |
vendor-enum34 | Vendor enum34 | Jeff Widman | 6 years |
vendor-six-consistently | Vendor `six` consistently | Jeff Widman | 6 years |
verify-timeouts-set-correctly | Error if connections_max_idle_ms not larger than request_timeout_ms | Jeff Widman | 6 years |
wait_for_it_1_0_0 | Add fixture support for upcoming 1.0.0 broker release | Dana Powers | 7 years |
waiting_on_godot | Issue 985: Clear memory wait condition before raising Exception | Dana Powers | 8 years |
wake_socketpair_exceptions | Catch socket.errors when sending / recving bytes on wake socketpair | Dana Powers | 8 years |
warn_dns_error | Warn dont raise on DNS lookup failures | Dana Powers | 8 years |
windows | Skip test that fails on windows | Dana Powers | 9 years |
workaround-pylint-bug | Add temp workaround for upstream pylint bug | Jeff Widman | 6 years |
wrap_ssl_after_connect | Wrap SSL sockets after connecting | Dana Powers | 6 years |
zk_autocommit | For zookeeper offset storage, set a "coordinator" with least_loaded_node | Dana Powers | 8 years |
|
Tag | Download | Author | Age |
2.0.2 | kafka-python-2.0.2.tar.gz | Dana Powers | 4 years |
2.0.1 | kafka-python-2.0.1.tar.gz | Dana Powers | 5 years |
2.0.0 | kafka-python-2.0.0.tar.gz | Dana Powers | 5 years |
1.4.7 | kafka-python-1.4.7.tar.gz | Dana Powers | 5 years |
1.4.6 | kafka-python-1.4.6.tar.gz | Dana Powers | 6 years |
1.4.5 | kafka-python-1.4.5.tar.gz | Dana Powers | 6 years |
1.4.4 | kafka-python-1.4.4.tar.gz | Dana Powers | 6 years |
1.4.3 | kafka-python-1.4.3.tar.gz | Dana Powers | 6 years |
1.4.2 | kafka-python-1.4.2.tar.gz | Dana Powers | 7 years |
1.4.1 | kafka-python-1.4.1.tar.gz | Dana Powers | 7 years |
1.4.0 | kafka-python-1.4.0.tar.gz | Dana Powers | 7 years |
1.3.5 | kafka-python-1.3.5.tar.gz | Dana Powers | 7 years |
1.3.4 | kafka-python-1.3.4.tar.gz | Dana Powers | 7 years |
1.3.3 | kafka-python-1.3.3.tar.gz | Dana Powers | 8 years |
1.3.2 | kafka-python-1.3.2.tar.gz | Dana Powers | 8 years |
1.3.1 | kafka-python-1.3.1.tar.gz | Dana Powers | 8 years |
1.3.0 | kafka-python-1.3.0.tar.gz | Dana Powers | 8 years |
1.2.5 | kafka-python-1.2.5.tar.gz | Dana Powers | 8 years |
1.2.4 | kafka-python-1.2.4.tar.gz | Dana Powers | 8 years |
1.2.3 | kafka-python-1.2.3.tar.gz | Dana Powers | 8 years |
1.2.2 | kafka-python-1.2.2.tar.gz | Dana Powers | 8 years |
1.2.1 | kafka-python-1.2.1.tar.gz | Dana Powers | 8 years |
1.2.0 | kafka-python-1.2.0.tar.gz | Dana Powers | 8 years |
1.1.1 | kafka-python-1.1.1.tar.gz | Dana Powers | 9 years |
1.1.0 | kafka-python-1.1.0.tar.gz | Dana Powers | 9 years |
1.0.2 | kafka-python-1.0.2.tar.gz | Dana Powers | 9 years |
1.0.1 | kafka-python-1.0.1.tar.gz | Dana Powers | 9 years |
1.0.0 | kafka-python-1.0.0.tar.gz | Dana Powers | 9 years |
v0.9.5 | kafka-python-0.9.5.tar.gz | Dana Powers | 9 years |
v0.9.4 | kafka-python-0.9.4.tar.gz | Dana Powers | 9 years |
v0.9.3 | kafka-python-0.9.3.tar.gz | David Arthur | 10 years |
v0.9.2 | kafka-python-0.9.2.tar.gz | Dana Powers | 10 years |
v0.9.1 | kafka-python-0.9.1.tar.gz | Dana Powers | 10 years |
v0.9.0 | kafka-python-0.9.0.tar.gz | Dana Powers | 11 years |
v0.8.0 | kafka-python-0.8.0.tar.gz | David Arthur | 11 years |
0.1-alpha | kafka-python-0.1-alpha.tar.gz | David Arthur | 12 years |