summaryrefslogtreecommitdiff
BranchCommit messageAuthorAge
0.10.0.1Use new release 0.10.0.1 for 0.10 testingDana Powers8 years
0.7Making version number compatible with future versionsDavid Arthur11 years
0.8Merge branch 'master' into 0.8David Arthur11 years
0.9Fix KafkaClient->SimpleClient referencesDana Powers8 years
0_10_1_0Update docsDana Powers8 years
0_10_1_1Switch to 0.10.1.1Dana Powers7 years
0_11_0_0Do not test fetched_size with fetch_max_bytes since 0.11 brokers will return ...Dana Powers7 years
0_11_0_1Update to 0.11.0.1 for travis test fixture; use as default if unspecifiedDana Powers7 years
0_11_0_2Use 0.11.0.2 kafka broker for integration testingDana Powers6 years
0_8_2_protocol_parser_tooRevert 703f0659 / fix 0.8.2 protocol quick detectionDana Powers5 years
1.3.5Don't use `kafka.common` internallyJeff Widman6 years
1.4.7Release 1.4.7Dana Powers5 years
1193-remove-old-simple-clientsAdd a bunch of TODOsJeff Widman5 years
1212-stop-using-mutable-types-for-default-arg-valuesStop using mutable types for default arg valuesJeff Widman7 years
1274-producer-raise-non-api-exceptionsRaise non-API exceptionsJeff Widman6 years
1_0_1Add kafka 1.0.1 release to test fixturesDana Powers6 years
1_4_0Release 1.4.0Dana Powers6 years
709Protect writes to wakeup socket with threading lockDana Powers8 years
741Avoid AttributeErrors in _unregister_cleanupDana Powers8 years
KAFKA-3117KAFKA-3117: handle metadata updates during consumer rebalanceDana Powers8 years
KAFKA-3196 KAFKA-3196: Add checksum and size to RecordMetadata and ConsumerRecordDana Powers8 years
KAFKA-3197KAFKA-3197: when max.in.flight.request.per.connection = 1, attempt to guarant...Dana Powers8 years
KAFKA-3388KAFKA-3388: Fix expiration of batches sitting in the accumulatorDana Powers8 years
KAFKA-3486KAFKA-3486: fix autocommit when partitions assigned manuallyDana Powers8 years
KAFKA-3960Fix offset fetch when partitions are manually assignedDana Powers8 years
KAFKA-8962-use-least-loaded-node-for-admin-describe-topicsKAFKA-8962: Use least_loaded_node() for describe_topics()Jeff Widman4 years
KAFKA_3888_heartbeat_threadFix lookup future is_done checkDana Powers6 years
KAFKA_3949_subscription_metadata_raceDont add commented-out codeDana Powers6 years
KAFKA_3977_defer_fetch_parsingMore testsDana Powers7 years
KAFKA_4034_coordinator_lookupKAFKA-4034: Avoid unnecessary consumer coordinator lookupDana Powers7 years
KAFKA_4160_rebalance_listener_lockIn the middle of kafka.coordinator.consumerDana Powers7 years
KAFKA_4160_rebalance_listener_without_lockKAFKA-4160: Ensure rebalance listener not called with coordinator lockDana Powers6 years
KAFKA_5512_notify_heartbeat_threadKAFKA-5512; Awake the heartbeat thread when timetoNextHeartbeat is equal to 0Dana Powers6 years
Remove-deprecated-ConnectionErrorRemove deprecated `ConnectionError`Jeff Widman5 years
Remove-deprecated-smallest-largestRemove deprecated `'smallest'`/`'largest'`Jeff Widman5 years
Remove-support-for-api_version-stringsRemove string support in `api_version`Jeff Widman5 years
Remove-weird-comment-lineRemove unused/weird comment lineJeff Widman5 years
Stop-shadowing-native-python-ConnectionError-exceptionStop shadowing `ConnectionError`Jeff Widman6 years
Update-docs-api_version_auto_timeout_msUpdate docs for api_version_auto_timeout_msJeff Widman5 years
absolute_importAlways absolute_importDana Powers8 years
accumulator_bugfixFix producer threading bug that could crash sender (dict changing during iter...Dana Powers8 years
add-a-snappy-dose-of-httpsUpdate remote urls: snappy, https, etcJeff Widman6 years
add-group-coordinator-lookupAdd group coordinator lookupJeff Widman5 years
add-license-to-wheelAdd license to wheelJeff Widman7 years
add-list-consumer-groups-offsetsAdd list_consumer_group_offsets()Jeff Widman5 years
add-lz4-and-snappy-to-extras_requirerename to `"zstd"`Jeff Widman4 years
add-python-37-supportcleanup java install scriptDana Powers5 years
add_makefileAdd build_intergation job for makefileTaras Voinarovskiy7 years
add_new_api_versionsAdd API version determination code for newer kafka brokersTaras Voinarovskyi4 years
admin_client_unpack_errorsFix response error checking in KafkaAdminClient send_to_controllerDana Powers5 years
any_api_versionDo not validate api_version against known versionsDana Powers6 years
appveyorConsidering appveyor testing for windowsDana Powers6 years
async_connect_sendRemove sleep check when no partitions assigned -- no longer neededDana Powers5 years
async_producer_connect_errorsCleanup new producer tests...Dana Powers8 years
async_producer_stopProducer.stop() now blocks until async thread completes (drop confusing timeo...Dana Powers8 years
at_exit_weakrefUse weakref when registering a producer.close atexit to fix normal gcDana Powers8 years
auth_recvvalidate sasl_mechanism against SaslHandShakeResponse enabled_mechanismsDana Powers7 years
authenticate_future_handlingHandle blocking socket recv during authenticationDana Powers7 years
await_reservedDont use soon-to-be-reserved keyword await as function name (FutureProduceRes...Dana Powers8 years
backoff_conn_reconnectReset last_attempt in conn connect testsDana Powers6 years
backoff_coordinator_retryBackoff on unavailable group coordinator retryDana Powers7 years
batch_expiration_messageImprove error message when expiring batches in KafkaProducerDana Powers7 years
batch_size_zeroSupport batch_size = 0 in producer buffersDana Powers8 years
be-explicit-with-validate_onlySet a clear default value for `validate_only`/`include_synonyms`Jeff Widman5 years
benchmark_fixupsFixups to benchmark scripts for py3 / new KafkaFixture interfaceDana Powers5 years
benchmarksAdapt benchmark scripts from https://github.com/mrafayaleem/kafka-jythonDana Powers8 years
better-struct-errorsGive better struct errorsJeff Widman6 years
blackout_timerMark last_attempt time during connection close to fix blackout calculationDana Powers7 years
bootstrap_clusterMaintain shadow bootstrap cluster metadataDana Powers5 years
bootstrap_cluster_metadataDo not user bootstrap_topics_filter unless topics is emptyDana Powers5 years
bootstrap_dns_lookupDont check connecting in old simple clientDana Powers6 years
bootstrap_selectSelect on sockets to avoid busy polling during bootstrapDana Powers7 years
break-consumer-operations-into-request-response-methodsBreak consumer operations into request / response methodsJeff Widman5 years
break-find-group-coordinator-into-request-response-methodsBreak FindCoordinator into request/response methodsJeff Widman5 years
bump-lz4Stop pinning lz4Jeff Widman6 years
bump-vendored-six-to-1.11.0Bump vendored `six` to `1.11.0`Jeff Widman6 years
bump_versionsTry to fix pylint issueTaras Voinarovskyi4 years
cancel_in_flightWhen closing a broker connection without error, fail in-flight-requests with ...Dana Powers7 years
catch_socket_errorIgnore socket.error when checking for protocol out of sync prior to socket closeDana Powers8 years
check-for-none-in-on-join-completeExplicitly check for `None` rather than FalseJeff Widman7 years
check-for-none-rather-than-falseExplicitly check for None rather than falseyJeff Widman7 years
check_invalid_metadataDont refresh metadata on failed group coordinator request unless neededDana Powers7 years
check_versionKakfaClient.check_version: Scan all brokers until a version is identified or ...Dana Powers8 years
check_version_0_10Add protocol support for ApiVersionRequest; identify 0.10 brokers in check_ve...Dana Powers8 years
clean_drain_coordinator_requestsAvoid unknown coordinator after client pollDana Powers7 years
cleanup-install-instructions-for-optional-libsCleanup install instructions for optional libsJeff Widman4 years
cleanup-kafka-admin-test-formattingCleanup formatting, no functional changesJeff Widman5 years
cleanup-max-bytes-testsMerge two tests that are very similarJeff Widman5 years
cleanup-testing-docMinor cleanup of testing docJeff Widman6 years
cleanupsIncrease test_producer end-to-end timeoutsDana Powers6 years
clear_gai_cacheFixup log format strDana Powers6 years
client_api_versionAdd api_version config to KafkaClient, deprecate str in favor of tuplesDana Powers8 years
client_send_raceAvoid race condition on client._conns in send()Dana Powers5 years
close_consumer_testsFix merge conflictDana Powers6 years
combine_send_bytesSend combined size and payload bytes to socket to avoid potentially split pac...Dana Powers8 years
commit_failed_message_fixupRemove old CommitFailed error message from coordinatorDana Powers6 years
compacted_offsetsUse explicit subscription state flag to handle seek() during message iterationDana Powers8 years
config_selectorExpose selector type as config optionDana Powers8 years
conn_check_version_max_in_flightMonkeypatch max_in_flight_requests_per_connection when checking broker versionDana Powers8 years
conn_close_short_circuitShort-circuit BrokerConnection.close() if already disconnectedDana Powers6 years
conn_delay_msFix BrokerConnection.connection_delay() -- return msDana Powers6 years
conn_immutable_host_port_afiMake BrokerConnection .host / .port / .afi immutable, use _sock_* attributes ...Dana Powers6 years
conn_legacyDelete KafkaConnection classDana Powers8 years
conn_lock_async_sendSynchronize puts to KafkaConsumer protocol buffer during async sendsDana Powers5 years
conn_lock_release_gssapi_oauthrelease lock on Exception in oauthDana Powers5 years
conn_logging_cleanupsLog connected as INFODana Powers6 years
conn_loop_bytesComment indentDana Powers6 years
conn_metricsInstrument bufferpool-wait-ratio metric in KafkaProducerDana Powers8 years
conn_metrics_fixHOTFIX: Fix BrokerConnectionMetrics when sensors already exist (i.e., on reco...Dana Powers8 years
conn_send_bufferAlways mock selector in KafkaClient testsDana Powers5 years
conn_send_timeoutUse socket timeout of request_timeout_ms to prevent blocking forever on sendDana Powers7 years
conn_state_callbackAdd state_change_callback to bootstrap connectionDana Powers8 years
conn_state_changeRemove close_connsDana Powers5 years
connect_blockingWhitespace cleanup in test_client_asyncDana Powers6 years
connect_blocking_fixupsOnly perform single dns lookup for connect_blocking; fix blocking timeout in ...Dana Powers6 years
connection_delay_infRely on selector to detect completed connection attemptsDana Powers5 years
connection_error_closeDo not re-close a disconnected connectionDana Powers7 years
consumer_heartbeat_fixesConsumer should timeout internal iterator if heartbeat ttl is expiredDana Powers8 years
consumer_iteratorRevert consumer iterators from max_poll_recordsDana Powers8 years
consumer_iterator_with_pollReturn float(inf) seconds instead of sys.maxsize int in coordinator time to n...Dana Powers5 years
consumer_poll_sleepKafkaConsumer.poll should sleep to prevent tight-loopsDana Powers8 years
consumer_rejoin_fixesImprove KafkaConsumer join group / only enable Heartbeat Thread during stable...Dana Powers5 years
convert-remaining-unittests-to-pytestBump failing test iterations to 100--is travis happy?Jeff Widman5 years
coordinator_client_deadlockAlways acquire client lock before coordinator lock to avoid deadlocksDana Powers6 years
coordinator_dead_error_loggingAlways include an error for logging when the coordinator is marked deadDana Powers7 years
coordinator_delAvoid some exceptions in Coordinator.__del__Dana Powers8 years
coordinator_lock_orderChange coordinator lock acquisition orderDana Powers5 years
coordinator_testsAdd ConsumerCoordinator unit testsDana Powers8 years
coordinator_unknown_heartbeatLog successful heartbeat as INFO; improve heartbeat response loggingDana Powers8 years
create_topics_v1CreateTopicsRequest / Response v1Dana Powers7 years
decode_errorsCatch response decode errors and log detailsDana Powers8 years
default_no_consumer_groupSet group_id for testingDana Powers7 years
defer_version_checkDefer version check until after bootstrap succeedsDana Powers6 years
delay-units-conversion-til-last-possiblepointDelay converting to secondsJeff Widman5 years
deprecation_warningsAdd DeprecationWarnings to legacy KafkaClient, Simple/MultiProcess/Consumer, ...Dana Powers8 years
differentiate-between-client-and-broker-version-errorsDifferentiate between client and broker version errorsJeff Widman5 years
disconnectsImprove socket disconnect handlingDana Powers8 years
docstring-pep8-cleanupVarious docstring / pep8 / code hygiene cleanupsJeff Widman5 years
document-methods-returning-noneDocument methods that return NoneJeff Widman6 years
dont-support-api-version-stringsRemove support for api versions as strings from KafkaAdminJeff Widman5 years
dont-use-broker-errors-for-client-side-problemsStop using broker-errors for client-side problemsJeff Widman5 years
dont-use-kafka.common-internallyDon't use `kafka.common` internallyJeff Widman6 years
double_compressionFix bug causing KafkaProducer to double-compress message batches on retryDana Powers8 years
drain_pending_coordinator_requestsDrain pending requests to the coordinator before initiating group rejoinDana Powers8 years
drain_requests_join_groupFix possible request draining in ensure_active_groupDana Powers7 years
drop_pytest_sugarUse latest pytest 3.4.0, but drop pytest-sugar due to incompatibilityDana Powers6 years
empty_broker_list_metadataremove unneded import in test_cluster.pyDana Powers6 years
errorsCleanup error loggingDana Powers8 years
except_timeoutCatch TimeoutError in BrokerConnection send/recvDana Powers5 years
exclude_internal_topicsRaise error during rebalance if subscribed topics are not authorizedDana Powers8 years
exp_backoffFix conn.connection_delayDana Powers7 years
expand-metrics-docsUse Sphinx warning syntaxJeff Widman7 years
fast_lookup_coordinator_resetUpdate commentDana Powers7 years
faster_validate_crcAvoid re-encoding for message crc checkDana Powers7 years
fetchDont send FetchRequest for (obviously) pending dataDana Powers8 years
fetch_compacted_offsetFix PartitionRecords handling of compacted messagesDana Powers6 years
fetch_partition_compressed_offsetFix for PartitionRecords has no attribute message_idx; add testDana Powers6 years
fetch_poll_backoffAvoid tight poll loop in consumer when brokers are downDana Powers6 years
fetchable_key_errorset.discard is much betterDana Powers6 years
fetcher_offset_out_of_rangeFix fetcher bug when processing offset out of rangeDana Powers7 years
fetcher_randomize_orderRandomize order of topics/partitions processed by fetcher to improve balanceDana Powers8 years
fetcher_send_no_wakeupDo not use wakeup when sending fetch requests from consumerDana Powers5 years
finish-bumping-lz4Bump `lz4` in `requirements-dev.txt`Jeff Widman6 years
fix-describe-groupsFix describe_groupsJeff Widman5 years
fix-list-groups-to-query-all-brokersFix list_consumer_groups() to query all brokersJeff Widman5 years
fix-minor-bug-with-printing-bytes-instanceFix two bugs in printing bytes instanceAndre Araujo6 years
fix-send-to-controllerFix send to controllerJeff Widman5 years
fix-sphinx-docsFix sphinx bullet pointsJeff Widman6 years
fix-sphinx-urlFix sphinx urlJeff Widman6 years
fix-typod-test-file-nameFix typo in file nameJeff Widman6 years
fix_close_socket_attribute_errorFix possible AttribueError during conn._close_socketDana Powers5 years
fix_fixture_version_warningUse test.fixtures.version not test.conftest.version to avoid warningsDana Powers5 years
fix_leaksDont warn on socket disconnections caused by KafkaClient.close()Dana Powers8 years
fix_memory_records_typoAdd missed raise in rare case.Taras6 years
fix_recordsAdd codec validators to record parser and builder for all formats.Taras6 years
fix_sasl_reconnectFix sasl reconnect bug: auth future must be reset on closeDana Powers7 years
fix_tests_1_4_7Follow up to PR 1782 -- fix testsDana Powers5 years
fixture_auto_portsDont include kafka.vendor in coverageDana Powers8 years
french_connectionCleanup AF_INET import in conn fixtureDana Powers8 years
fresh_brokersDrop old brokers when rebuilding broker metadataDana Powers7 years
gc_debugLog __del__ cleanupsDana Powers6 years
gen_ssl_resourceGenerate SSL certificates for local testingDana Powers5 years
get_api_versions_fixDont recheck version if api_versions data is already cachedDana Powers5 years
group_id_noneDisable auto-commit / group assignment in producer testDana Powers8 years
gssapi_authentication_completeImport structDana Powers7 years
handle_api_versionsAdd private map of api key -> min/max versions to BrokerConnectionDana Powers7 years
handle_disconnectRefresh metadata on failed connection attemptsDana Powers8 years
heartbeat_cleanupsrevert poll timeout changeDana Powers6 years
heartbeat_loggingHeartbeat thread start / closeDana Powers6 years
heartbeat_wait_brokers_downCheck for immediate failure when looking up coordinator in heartbeat threadDana Powers6 years
hw_crc32cAdd doc notice of optional `crc32c` packageTaras6 years
idle_sleepPass consumer timeout to client.poll() in iterator; check timeout before iter...Dana Powers8 years
initial_metadata_snapshotUse subscription arg, not self._subscriptionDana Powers7 years
ipv6_scope_idConnect with sockaddrs to support non-zero ipv6 scope idsDana Powers6 years
issue-1082-offset-and-metadataOptionally return OffsetAndMetadata from consumer.committed(tp)Dana Powers4 years
issue-1088-full-topic-metadata-skip-error-loggingDo not log topic-specific errors in full metadata fetchDana Powers4 years
issue-1219-closed-consumerStopIteration when consumer closedDana Powers4 years
issue-1931-logging-producer-deadlockRetain blocking on sender thread for del(producer)Dana Powers4 years
issue-1943-coordinator-node-not-ready-debugLog retriable coordinator NodeNotReady, TooManyInFlightRequests as debug not ...Dana Powers4 years
issue-1963-reset-override-configsReset conn configs on exception in conn.check_version()Dana Powers4 years
issue-26Starting work on fixing offset commitsDavid Arthur11 years
issue1036_offset_by_timeAdded unit tests for fetcher's `_reset_offset` and related functions.Taras Voinarovskiy7 years
issue1155Make UnknownTopicOrPartitionError retriable errorTaras Voinarovskiy7 years
issue_1399Use local copies in Fetcher._fetchable_partitions to avoid mutation errorsDana Powers6 years
issue_619Improve auto-commit task handling when group_id is NoneDana Powers8 years
iterator_fetchesSleep in KafkaConsumer iterator if no partition assignment; dont block in pol...Dana Powers8 years
iterator_timeoutFix internal timeout / sleep handling in consumer iteratorDana Powers8 years
jeffwidman-patch-1No need to cast to listJeff Widman5 years
join_future_raceFix race condition in coordinator join_future handlingDana Powers6 years
kafka-0.8.0-releaseMerge pull request #129 from wizzat/kafka-0.8.0-releaseDana Powers10 years
kafka-2136KAFKA-2136: support Fetch and Produce v1 (throttle_time_ms)Dana Powers8 years
kafka-2978KAFKA-2978: consumer stops fetching when consumed and fetch positions get out...Dana Powers8 years
kafka-3318Remove unused importsDana Powers8 years
kafka-snakeScratching on __main__Dana Powers6 years
kafka_1_0_0Add kafka 1.0.0 to travis integration testsDana Powers6 years
kafka_conn_locking_tooCheck _can_send_recv with lock to verify stateDana Powers5 years
kafka_conn_with_lockfixup var name for consistencyDana Powers5 years
kafka_error_strArgs are optional in BrokerResponseError strDana Powers7 years
kafka_producerAdd KafkaProducer to autodocs and READMEDana Powers8 years
kafka_version_testsRefactor kafka_versions to support arbitrary operators (> >= < <= ! =)Dana Powers8 years
larsjsol-sasl_plainUse callbacks for sasl handshake request / responseDana Powers8 years
leak_z4Alter test skips: python-lz4 works on python26, but not pypyDana Powers7 years
least_loaded_nodeUpdate KafkaClient.least_loaded_nodeDana Powers8 years
legacy_records_refactorAdded limit of 100 bytes for Bytes debug printsTaras Voinarovskiy7 years
lock_client_check_versionlock client.check_versionDana Powers5 years
log_check_versionRe-enable logging during broker version checkDana Powers6 years
lower_consumer_timeoutCombine two `poll_ms` defs into oneJeff Widman5 years
lz4Add lz4 to tox environment depsDana Powers8 years
lz4_0_10Update lz4 codec testsDana Powers8 years
lz4_fixupHandle broken LZ4 framing; switch to lz4tools + xxhashDana Powers8 years
masterAllow disabling thread wakeup in send_request_to_node (#2335)Andrew Zhang14 months
max_poll_recordsFixup iteratorsDana Powers8 years
max_records_intValidate max_records in KafkaConsumer.pollDana Powers6 years
maybe_refreh_metadata_reconnect_delayRecheck connecting nodes sooner when refreshing metadataDana Powers5 years
maybe_refresh_metadata_no_wakeupDont wakeup during maybe_refresh_metadata -- it is only called by poll()Dana Powers5 years
merge-_find_coordinator_ids-methodsMerge _find_coordinator_id methodsJeff Widman4 years
message_format_v1Add some simple message protocol testsDana Powers8 years
message_set_encode_sizeAlways encode size with MessageSetDana Powers8 years
metadata_refresh_backoffAvoid busy poll during metadata refresh failure with retry_backoff_msDana Powers8 years
metadata_v1Use MetadataRequest v1 for 0.10+ api_versionDana Powers8 years
metadata_wait_for_connectAvoid multiple connection attempts when refreshing metadataDana Powers7 years
metadata_with_partitionsFixup ClusterMetadata __str__Dana Powers8 years
migrate-from-unittest-to-pytesttest-this-tooJeff Widman6 years
minor-exception-cleanupMinor Exception cleanupJeff Widman6 years
mock_dns_test_connMock dns lookups in test_connDana Powers5 years
more_errorsAdd new broker response errorsDana Powers7 years
more_gssapi_fixesCleanup gssapi code; fix bug report re AttributeError.Dana Powers7 years
more_metricsAdd KafkaClient metricsDana Powers8 years
more_sasl_fixesFix more gssapi errorsDana Powers7 years
murmur2_asciiMake DefaultPartitioner importable from kafka.partitionerDana Powers8 years
name_nodeInclude the node id in BrokerConnection __repr__Dana Powers7 years
no_ifrs_short_pollReduce client poll timeout when no ifrsDana Powers5 years
no_sleepDrop unused sleep kwarg to pollDana Powers7 years
no_sleep_til_brooklynWakeup socket optimizationsDana Powers8 years
node_not_readyImprove KafkaClient connect and ready handlingDana Powers8 years
nonblocking_wake_socketsUse _need_wakeup flag to avoid multiple writes to wake socketDana Powers5 years
none_least_loaded_nodeCheck for None returned from least_loaded_node when no brokers are availableDana Powers8 years
null_loggerAdd logging NullHandler to avoid No Handlers warningsDana Powers8 years
old_ssl_exceptionImprove SSLWantReadError handling when ssl not availableDana Powers5 years
partial_messagesFix bug in MessageSet decoding that crashed multi-partition FetchResponseDana Powers8 years
pending_completionsMove callback processing from BrokerConnection to KafkaClientDana Powers7 years
pin_depsPin pylint and lz4 to avoid breaking testsDana Powers6 years
popped_conn_closeDont treat popped conn.close() as failure in state change callbackDana Powers5 years
produce_fetch_v2Use Fetch/Produce API v2 for brokers >= 0.10 (uses message format v1)Dana Powers8 years
producer_defaultsRename _DEFAULT_CONFIG -> DEFAULT_CONFIG in KafkaProducerDana Powers8 years
producer_new_topicMock client.ensure_topic_exists in test_producer_sync_fail_on_errorDana Powers8 years
protocol_1_0_0Add Request/Response structs for kafka broker 1.0.0Dana Powers6 years
protocol_parserAdd kafka.protocol.parser.KafkaProtocol w/ receive and sendDana Powers7 years
protocol_updatesCleanup protocol change commentsDana Powers7 years
protocol_versionsUse version-indexed lists for request/response protocol structsDana Powers8 years
pylint_1_8_2pylint 1.8.2Dana Powers6 years
pylint_fixupIgnore not-context-manager pylint errorDana Powers7 years
queue-fixupTrying to get ReadTheDocs workingDavid Arthur9 years
range_assignorAdd RangePartitionAssignor (and use as default); add assignor testsDana Powers8 years
ready_metadata_kwargAdd optional kwarg to ready and is_ready to disable metadata-priority logicDana Powers7 years
receive_bytes_pipeBrokerConnection.receive_bytes(data) -> response eventsDana Powers7 years
reconnect_backoff_gaiOnly increase reconnect backoff if all addrinfos have been triedDana Powers6 years
reconnect_backoff_max_ms_doc_updateImprove docs for reconnect_backoff_max_msDana Powers4 years
record_metadata_simplifyMinor optimization: inline check for no callbacksDana Powers8 years
reduce_client_locksDo not require client lock for read-only operationsDana Powers5 years
refactorAdd state_change_callback to BrokerConnectionDana Powers8 years
reference_cleanup_closeImprove KafkaConsumer cleanupDana Powers6 years
releaseAdd changelog to sphinx docs; remove SimpleProducer from API list and move AP...Dana Powers8 years
release-0.9.xTrying a different passwordDavid Arthur10 years
remove-pylint-hackRemove pylint workaround since upstream fixedJeff Widman3 years
remove-some-unused-codeAdd a bunch of TODOsJeff Widman5 years
remove-unused-importwill-this-fix-tests-or-change-to-import-from-conn.dns_lookup?Jeff Widman5 years
remove-unused-skip_double_compressed_messagesRemove unused `skip_double_compressed_messages`Jeff Widman5 years
remove_bad_testDrop bad disconnect test -- just use the mocked-socket testDana Powers7 years
request_response_classesDerive all api classes from Request / Response base classesDana Powers7 years
request_timeout_docsFix KafkaConsumer docstring for request_timeout_ms defaultDana Powers6 years
reset_reconnect_backoff_connectedReset reconnect backoff on SSL connectionDana Powers5 years
return_state_conn_fixReturn connection state explicitly after close in connect()Dana Powers5 years
revert-1345-heartbeat_cleanupsRevert "Name heartbeat thread with group_id; use backoff when polling (#1345)"Dana Powers6 years
sansioprotocol notesDana Powers6 years
sasl_fixesSmall fixes to SASL documentation and logging; validate security_protocolDana Powers7 years
selector_closeClose leaked selector in version checkDana Powers6 years
selectorsUse selectors module in KafkaClientDana Powers8 years
send_first_pollSend pending requests before waiting for responsesDana Powers5 years
sender_dont_wakeupAvoid call to wakeup from sender thread for maybe_connectDana Powers5 years
sensor_quota_messageFix quota violation exception messageDana Powers8 years
separate_coordinator_connspDana Powers5 years
serialize_interfaceAdd kafka.serializer interfacesDana Powers7 years
short_circuit_node_not_readyDont prioritize metadata requests over consumer group api callsDana Powers7 years
simpleStart test fixtures in new session to avoid propagating signals (i.e., Ctrl-C)Dana Powers8 years
simple_producer_async_sendCheck kwargs for deprecated async optionDana Powers6 years
simplify-version-checking-using-pytest-skipifCleanup handling of KAFKA_VERSION env var in testsJeff Widman5 years
sixVendor six 1.10.0Dana Powers8 years
skip_autocommit_consumer_closeOptionally skip auto-commit during consumer.closeDana Powers7 years
skip_integration_testsFix skipped integration tests if KAFKA_VERSION unsetDana Powers6 years
sock_send_bytesHandle partial socket send()Dana Powers8 years
socket_buffer_size_optionalDont override system rcvbuf or sndbuf unless user configures explicitlyDana Powers8 years
socket_optionsUse socket_options configuration to setsockopts(). Default TCP_NODELAYDana Powers8 years
ssl_handshake_errorsCatch socket errors during ssl handshakeDana Powers7 years
ssl_set_ciphersAllow configuration of SSL CiphersDana Powers5 years
ssl_supportAttempt to add ssl support to kafka fixturesDana Powers8 years
state_change_callback_no_lock_closeDont call conn.close() with client _lock in state change callbackDana Powers5 years
stop-pinning-pylintStop pinning `pylint`Jeff Widman6 years
streamsTest streams thingyDana Powers6 years
struct-pre-compilationPre-compile pack/unpack function callsbillyevans6 years
struct_kwargsFix kwarg handing in StructDana Powers7 years
subscription_copyReturn copy of subscriptionDana Powers7 years
task_poll_timeoutImprove KafkaConsumer iterator loop timeoutsDana Powers8 years
test_cleanupsMinor test cleanupsDana Powers6 years
testingMove logging format config to tox.ini to avoid duplicate log capture in pytes...Dana Powers8 years
threadsafe_pending_responsesFix pending completion IndexError bug caused by multiple threadsDana Powers6 years
timeout_idle_connectionsAdd support for connections_max_idle_msDana Powers7 years
timeout_noresponseAlso/continue to check for timeouts in BrokerConnection.recv()Dana Powers7 years
timeout_ssl_connTimeout all unconnected conns (incl SSL) after request_timeout_msDana Powers5 years
topic_partition_type_errorRaise TypeError in KafkaConsumer when partition is not a TopicPartitionDana Powers8 years
travis_upgradeAdd py35 to tox testingDana Powers8 years
truncate_bufferAlways truncate deallocated produce message buffersDana Powers8 years
unrecurse_unpack_message_setAdd skip_double_compressed_messages option to KafkaConsumerDana Powers8 years
update-rtd-linksUpdate RTD links with https / .ioJeff Widman7 years
use-TypeErrorUse TypeError for invalid typeJeff Widman5 years
use-explicit-tuples-for-stringsBe explicit with tuples for %s formattingJeff Widman5 years
use-raw-in-case-string-overridenUse raw in case string overridenJeff Widman6 years
v2_recordsAdd DefaultRecordBatch implementation aka V2 message format parser/builder.Taras Voinarovskiy7 years
validate_serialized_bytesValidate that serializers generate bytes-like (or None) dataDana Powers6 years
vendor-enum34Vendor enum34Jeff Widman6 years
vendor-six-consistentlyVendor `six` consistentlyJeff Widman6 years
verify-timeouts-set-correctlyError if connections_max_idle_ms not larger than request_timeout_msJeff Widman5 years
wait_for_it_1_0_0Add fixture support for upcoming 1.0.0 broker releaseDana Powers7 years
waiting_on_godotIssue 985: Clear memory wait condition before raising ExceptionDana Powers7 years
wake_socketpair_exceptionsCatch socket.errors when sending / recving bytes on wake socketpairDana Powers7 years
warn_dns_errorWarn dont raise on DNS lookup failuresDana Powers7 years
windowsSkip test that fails on windowsDana Powers8 years
workaround-pylint-bugAdd temp workaround for upstream pylint bugJeff Widman6 years
wrap_ssl_after_connectWrap SSL sockets after connectingDana Powers5 years
zk_autocommitFor zookeeper offset storage, set a "coordinator" with least_loaded_nodeDana Powers8 years