kafka-python
0.9.4-dev
Install
Tests
Usage
API reference
kafka-python
Docs
»
Index
_
|
A
|
B
|
C
|
D
|
E
|
F
|
G
|
H
|
I
|
K
|
L
|
M
|
N
|
O
|
P
|
R
|
S
|
T
|
U
|
V
|
W
|
X
_
__enter__() (kafka.consumer.simple.FetchContext method)
(kafka.context.OffsetCommitContext method)
__exit__() (kafka.consumer.simple.FetchContext method)
(kafka.context.OffsetCommitContext method)
__getnewargs__() (kafka.common.BrokerMetadata method)
(kafka.common.FetchRequest method)
(kafka.common.FetchResponse method)
(kafka.common.KafkaMessage method)
(kafka.common.Message method)
(kafka.common.MetadataRequest method)
(kafka.common.MetadataResponse method)
(kafka.common.OffsetAndMessage method)
(kafka.common.OffsetCommitRequest method)
(kafka.common.OffsetCommitResponse method)
(kafka.common.OffsetFetchRequest method)
(kafka.common.OffsetFetchResponse method)
(kafka.common.OffsetRequest method)
(kafka.common.OffsetResponse method)
(kafka.common.PartitionMetadata method)
(kafka.common.ProduceRequest method)
(kafka.common.ProduceResponse method)
(kafka.common.TopicAndPartition method)
(kafka.common.TopicMetadata method)
(kafka.consumer.kafka.OffsetsStruct method)
__getstate__() (kafka.common.BrokerMetadata method)
(kafka.common.FetchRequest method)
(kafka.common.FetchResponse method)
(kafka.common.KafkaMessage method)
(kafka.common.Message method)
(kafka.common.MetadataRequest method)
(kafka.common.MetadataResponse method)
(kafka.common.OffsetAndMessage method)
(kafka.common.OffsetCommitRequest method)
(kafka.common.OffsetCommitResponse method)
(kafka.common.OffsetFetchRequest method)
(kafka.common.OffsetFetchResponse method)
(kafka.common.OffsetRequest method)
(kafka.common.OffsetResponse method)
(kafka.common.PartitionMetadata method)
(kafka.common.ProduceRequest method)
(kafka.common.ProduceResponse method)
(kafka.common.TopicAndPartition method)
(kafka.common.TopicMetadata method)
(kafka.consumer.kafka.OffsetsStruct method)
__iter__() (kafka.consumer.multiprocess.MultiProcessConsumer method)
(kafka.MultiProcessConsumer method)
(kafka.consumer.MultiProcessConsumer method)
__nonzero__() (kafka.context.OffsetCommitContext method)
__repr__() (kafka.common.BrokerMetadata method)
(kafka.common.FetchRequest method)
(kafka.common.FetchResponse method)
(kafka.common.KafkaMessage method)
(kafka.common.Message method)
(kafka.common.MetadataRequest method)
(kafka.common.MetadataResponse method)
(kafka.common.OffsetAndMessage method)
(kafka.common.OffsetCommitRequest method)
(kafka.common.OffsetCommitResponse method)
(kafka.common.OffsetFetchRequest method)
(kafka.common.OffsetFetchResponse method)
(kafka.common.OffsetRequest method)
(kafka.common.OffsetResponse method)
(kafka.common.PartitionMetadata method)
(kafka.common.ProduceRequest method)
(kafka.common.ProduceResponse method)
(kafka.common.TopicAndPartition method)
(kafka.common.TopicMetadata method)
(kafka.consumer.kafka.OffsetsStruct method)
A
ACK_AFTER_CLUSTER_COMMIT (kafka.producer.base.Producer attribute)
ACK_AFTER_LOCAL_WRITE (kafka.producer.base.Producer attribute)
ACK_NOT_REQUIRED (kafka.producer.base.Producer attribute)
attributes (kafka.common.Message attribute)
B
BrokerMetadata (class in kafka.common)
BrokerNotAvailableError
BrokerResponseError
brokers (kafka.common.MetadataResponse attribute)
BufferUnderflowError
C
check_error() (in module kafka.common)
ChecksumError
CLIENT_ID (kafka.client.KafkaClient attribute)
(kafka.KafkaClient attribute)
close() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
(kafka.KafkaConnection method)
(kafka.conn.KafkaConnection method)
collect_hosts() (in module kafka.conn)
commit (kafka.consumer.kafka.OffsetsStruct attribute)
commit() (kafka.consumer.base.Consumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
(kafka.consumer.kafka.KafkaConsumer method)
(kafka.context.OffsetCommitContext method)
commit_partition_offsets() (kafka.context.OffsetCommitContext method)
configure() (kafka.consumer.kafka.KafkaConsumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
ConnectionError
Consumer (class in kafka.consumer.base)
ConsumerFetchSizeTooSmall
ConsumerNoMoreData
ConsumerTimeout
copy() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
(kafka.KafkaConnection method)
(kafka.conn.KafkaConnection method)
crc32() (in module kafka.util)
create_gzip_message() (in module kafka)
(in module kafka.protocol)
create_message() (in module kafka)
(in module kafka.protocol)
create_message_set() (in module kafka.protocol)
create_snappy_message() (in module kafka)
(in module kafka.protocol)
D
decode_fetch_response() (kafka.protocol.KafkaProtocol class method)
decode_metadata_response() (kafka.protocol.KafkaProtocol class method)
decode_offset_commit_response() (kafka.protocol.KafkaProtocol class method)
decode_offset_fetch_response() (kafka.protocol.KafkaProtocol class method)
decode_offset_response() (kafka.protocol.KafkaProtocol class method)
decode_produce_response() (kafka.protocol.KafkaProtocol class method)
DEFAULT_ACK_TIMEOUT (kafka.producer.base.Producer attribute)
E
encode_fetch_request() (kafka.protocol.KafkaProtocol class method)
encode_metadata_request() (kafka.protocol.KafkaProtocol class method)
encode_offset_commit_request() (kafka.protocol.KafkaProtocol class method)
encode_offset_fetch_request() (kafka.protocol.KafkaProtocol class method)
encode_offset_request() (kafka.protocol.KafkaProtocol class method)
encode_produce_request() (kafka.protocol.KafkaProtocol class method)
ensure_topic_exists() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
errno (kafka.common.BrokerNotAvailableError attribute)
(kafka.common.InvalidFetchRequestError attribute)
(kafka.common.InvalidMessageError attribute)
(kafka.common.LeaderNotAvailableError attribute)
(kafka.common.MessageSizeTooLargeError attribute)
(kafka.common.NotLeaderForPartitionError attribute)
(kafka.common.OffsetMetadataTooLargeError attribute)
(kafka.common.OffsetOutOfRangeError attribute)
(kafka.common.ReplicaNotAvailableError attribute)
(kafka.common.RequestTimedOutError attribute)
(kafka.common.StaleControllerEpochError attribute)
(kafka.common.StaleLeaderEpochCodeError attribute)
(kafka.common.UnknownError attribute)
(kafka.common.UnknownTopicOrPartitionError attribute)
error (kafka.common.FetchResponse attribute)
(kafka.common.OffsetCommitResponse attribute)
(kafka.common.OffsetFetchResponse attribute)
(kafka.common.OffsetResponse attribute)
(kafka.common.PartitionMetadata attribute)
(kafka.common.ProduceResponse attribute)
(kafka.common.TopicMetadata attribute)
F
FailedPayloadsError
fetch (kafka.consumer.kafka.OffsetsStruct attribute)
FETCH_KEY (kafka.protocol.KafkaProtocol attribute)
fetch_last_known_offsets() (kafka.consumer.base.Consumer method)
fetch_messages() (kafka.consumer.kafka.KafkaConsumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
FetchContext (class in kafka.consumer.simple)
FetchRequest (class in kafka.common)
FetchResponse (class in kafka.common)
G
get_message() (kafka.consumer.simple.SimpleConsumer method)
(kafka.SimpleConsumer method)
(kafka.consumer.SimpleConsumer method)
get_messages() (kafka.consumer.multiprocess.MultiProcessConsumer method)
(kafka.MultiProcessConsumer method)
(kafka.SimpleConsumer method)
(kafka.consumer.MultiProcessConsumer method)
(kafka.consumer.SimpleConsumer method)
(kafka.consumer.simple.SimpleConsumer method)
get_partition_ids_for_topic() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
get_partition_offsets() (kafka.consumer.kafka.KafkaConsumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
group_by_topic_and_partition() (in module kafka.util)
gzip_decode() (in module kafka.codec)
gzip_encode() (in module kafka.codec)
H
handle_out_of_range() (kafka.context.OffsetCommitContext method)
has_gzip() (in module kafka.codec)
has_metadata_for_topic() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
has_snappy() (in module kafka.codec)
HashedPartitioner (class in kafka)
(class in kafka.partitioner)
(class in kafka.partitioner.hashed)
highwater (kafka.consumer.kafka.OffsetsStruct attribute)
highwaterMark (kafka.common.FetchResponse attribute)
host (kafka.common.BrokerMetadata attribute)
I
ID_GEN (kafka.client.KafkaClient attribute)
(kafka.KafkaClient attribute)
InvalidFetchRequestError
InvalidMessageError
isr (kafka.common.PartitionMetadata attribute)
K
kafka (module)
kafka.client (module)
kafka.codec (module)
kafka.common (module)
kafka.conn (module)
kafka.consumer (module)
kafka.consumer.base (module)
kafka.consumer.kafka (module)
kafka.consumer.multiprocess (module)
kafka.consumer.simple (module)
kafka.context (module)
kafka.partitioner (module)
kafka.partitioner.base (module)
kafka.partitioner.hashed (module)
kafka.partitioner.roundrobin (module)
kafka.producer (module)
kafka.producer.base (module)
kafka.producer.keyed (module)
kafka.producer.simple (module)
kafka.protocol (module)
kafka.util (module)
kafka_bytestring() (in module kafka.util)
KafkaClient (class in kafka)
(class in kafka.client)
KafkaConfigurationError
KafkaConnection (class in kafka)
(class in kafka.conn)
KafkaConsumer (class in kafka)
(class in kafka.consumer)
(class in kafka.consumer.kafka)
KafkaError
KafkaMessage (class in kafka.common)
KafkaProtocol (class in kafka.protocol)
KafkaTimeoutError
KafkaUnavailableError
key (kafka.common.KafkaMessage attribute)
(kafka.common.Message attribute)
KeyedProducer (class in kafka)
(class in kafka.producer)
(class in kafka.producer.keyed)
L
leader (kafka.common.PartitionMetadata attribute)
LeaderNotAvailableError
load_metadata_for_topics() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
M
magic (kafka.common.Message attribute)
mark() (kafka.context.OffsetCommitContext method)
max_bytes (kafka.common.FetchRequest attribute)
max_offsets (kafka.common.OffsetRequest attribute)
Message (class in kafka.common)
message (kafka.common.BrokerNotAvailableError attribute)
(kafka.common.InvalidFetchRequestError attribute)
(kafka.common.InvalidMessageError attribute)
(kafka.common.LeaderNotAvailableError attribute)
(kafka.common.MessageSizeTooLargeError attribute)
(kafka.common.NotLeaderForPartitionError attribute)
(kafka.common.OffsetAndMessage attribute)
(kafka.common.OffsetMetadataTooLargeError attribute)
(kafka.common.OffsetOutOfRangeError attribute)
(kafka.common.ReplicaNotAvailableError attribute)
(kafka.common.RequestTimedOutError attribute)
(kafka.common.StaleControllerEpochError attribute)
(kafka.common.StaleLeaderEpochCodeError attribute)
(kafka.common.UnknownError attribute)
(kafka.common.UnknownTopicOrPartitionError attribute)
messages (kafka.common.FetchResponse attribute)
(kafka.common.ProduceRequest attribute)
MessageSizeTooLargeError
metadata (kafka.common.OffsetCommitRequest attribute)
(kafka.common.OffsetFetchResponse attribute)
METADATA_KEY (kafka.protocol.KafkaProtocol attribute)
MetadataRequest (class in kafka.common)
MetadataResponse (class in kafka.common)
MultiProcessConsumer (class in kafka)
(class in kafka.consumer)
(class in kafka.consumer.multiprocess)
N
next() (kafka.consumer.kafka.KafkaConsumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
nodeId (kafka.common.BrokerMetadata attribute)
NotLeaderForPartitionError
O
offset (kafka.common.FetchRequest attribute)
(kafka.common.KafkaMessage attribute)
(kafka.common.OffsetAndMessage attribute)
(kafka.common.OffsetCommitRequest attribute)
(kafka.common.OffsetFetchResponse attribute)
(kafka.common.ProduceResponse attribute)
OFFSET_COMMIT_KEY (kafka.protocol.KafkaProtocol attribute)
OFFSET_FETCH_KEY (kafka.protocol.KafkaProtocol attribute)
OFFSET_KEY (kafka.protocol.KafkaProtocol attribute)
OffsetAndMessage (class in kafka.common)
OffsetCommitContext (class in kafka.context)
OffsetCommitRequest (class in kafka.common)
OffsetCommitResponse (class in kafka.common)
OffsetFetchRequest (class in kafka.common)
OffsetFetchResponse (class in kafka.common)
OffsetMetadataTooLargeError
OffsetOutOfRangeError
OffsetRequest (class in kafka.common)
OffsetResponse (class in kafka.common)
offsets (kafka.common.OffsetResponse attribute)
offsets() (kafka.consumer.kafka.KafkaConsumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
OffsetsStruct (class in kafka.consumer.kafka)
P
partition (kafka.common.FetchRequest attribute)
(kafka.common.FetchResponse attribute)
(kafka.common.KafkaMessage attribute)
(kafka.common.OffsetCommitRequest attribute)
(kafka.common.OffsetCommitResponse attribute)
(kafka.common.OffsetFetchRequest attribute)
(kafka.common.OffsetFetchResponse attribute)
(kafka.common.OffsetRequest attribute)
(kafka.common.OffsetResponse attribute)
(kafka.common.PartitionMetadata attribute)
(kafka.common.ProduceRequest attribute)
(kafka.common.ProduceResponse attribute)
(kafka.common.TopicAndPartition attribute)
partition() (kafka.HashedPartitioner method)
(kafka.RoundRobinPartitioner method)
(kafka.partitioner.HashedPartitioner method)
(kafka.partitioner.RoundRobinPartitioner method)
(kafka.partitioner.base.Partitioner method)
(kafka.partitioner.hashed.HashedPartitioner method)
(kafka.partitioner.roundrobin.RoundRobinPartitioner method)
Partitioner (class in kafka.partitioner.base)
PartitionMetadata (class in kafka.common)
partitions (kafka.common.TopicMetadata attribute)
pending() (kafka.consumer.base.Consumer method)
port (kafka.common.BrokerMetadata attribute)
PRODUCE_KEY (kafka.protocol.KafkaProtocol attribute)
Producer (class in kafka.producer.base)
ProduceRequest (class in kafka.common)
ProduceResponse (class in kafka.common)
ProtocolError
provide_partition_info() (kafka.consumer.simple.SimpleConsumer method)
(kafka.SimpleConsumer method)
(kafka.consumer.SimpleConsumer method)
R
read_int_string() (in module kafka.util)
read_short_string() (in module kafka.util)
recv() (kafka.conn.KafkaConnection method)
(kafka.KafkaConnection method)
ReentrantTimer (class in kafka.util)
reinit() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
(kafka.KafkaConnection method)
(kafka.conn.KafkaConnection method)
relative_unpack() (in module kafka.util)
ReplicaNotAvailableError
replicas (kafka.common.PartitionMetadata attribute)
RequestTimedOutError
reset_all_metadata() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
reset_topic_metadata() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
rollback() (kafka.context.OffsetCommitContext method)
RoundRobinPartitioner (class in kafka)
(class in kafka.partitioner)
(class in kafka.partitioner.roundrobin)
S
seek() (kafka.consumer.simple.SimpleConsumer method)
(kafka.SimpleConsumer method)
(kafka.consumer.SimpleConsumer method)
send() (kafka.conn.KafkaConnection method)
(kafka.KafkaConnection method)
(kafka.KeyedProducer method)
(kafka.producer.KeyedProducer method)
(kafka.producer.keyed.KeyedProducer method)
send_fetch_request() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
send_messages() (kafka.KeyedProducer method)
(kafka.SimpleProducer method)
(kafka.producer.KeyedProducer method)
(kafka.producer.SimpleProducer method)
(kafka.producer.base.Producer method)
(kafka.producer.keyed.KeyedProducer method)
(kafka.producer.simple.SimpleProducer method)
send_metadata_request() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
send_offset_commit_request() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
send_offset_fetch_request() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
send_offset_request() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
send_produce_request() (kafka.client.KafkaClient method)
(kafka.KafkaClient method)
set_topic_partitions() (kafka.consumer.kafka.KafkaConsumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
SimpleConsumer (class in kafka)
(class in kafka.consumer)
(class in kafka.consumer.simple)
SimpleProducer (class in kafka)
(class in kafka.producer)
(class in kafka.producer.simple)
snappy_decode() (in module kafka.codec)
snappy_encode() (in module kafka.codec)
StaleControllerEpochError
StaleLeaderEpochCodeError
start() (kafka.util.ReentrantTimer method)
stop() (kafka.consumer.base.Consumer method)
(kafka.MultiProcessConsumer method)
(kafka.consumer.MultiProcessConsumer method)
(kafka.consumer.multiprocess.MultiProcessConsumer method)
(kafka.producer.base.Producer method)
(kafka.util.ReentrantTimer method)
T
task_done (kafka.consumer.kafka.OffsetsStruct attribute)
task_done() (kafka.consumer.kafka.KafkaConsumer method)
(kafka.KafkaConsumer method)
(kafka.consumer.KafkaConsumer method)
time (kafka.common.OffsetRequest attribute)
topic (kafka.common.FetchRequest attribute)
(kafka.common.FetchResponse attribute)
(kafka.common.KafkaMessage attribute)
(kafka.common.OffsetCommitRequest attribute)
(kafka.common.OffsetCommitResponse attribute)
(kafka.common.OffsetFetchRequest attribute)
(kafka.common.OffsetFetchResponse attribute)
(kafka.common.OffsetRequest attribute)
(kafka.common.OffsetResponse attribute)
(kafka.common.PartitionMetadata attribute)
(kafka.common.ProduceRequest attribute)
(kafka.common.ProduceResponse attribute)
(kafka.common.TopicAndPartition attribute)
(kafka.common.TopicMetadata attribute)
TopicAndPartition (class in kafka.common)
TopicMetadata (class in kafka.common)
topics (kafka.common.MetadataRequest attribute)
(kafka.common.MetadataResponse attribute)
U
UnknownError
UnknownTopicOrPartitionError
UnsupportedCodecError
update_consumer_offsets() (kafka.context.OffsetCommitContext method)
V
value (kafka.common.KafkaMessage attribute)
(kafka.common.Message attribute)
W
write_int_string() (in module kafka.util)
write_short_string() (in module kafka.util)
X
x (in module kafka.common)