以下是我为 kafka 生产者编写的 python 编码,我不确定消息是否能够发布到 Kafka Broker。因为消费者端没有收到任何消息。当我使用生产者控制台命令对其进行测试时,我的消费者 python 程序运行良好。
from __future__ import print_function
import sys
from pyspark import SparkContext
from kafka import KafkaClient, SimpleProducer
if __name__ == "__main__":
if len(sys.argv) != 2:
print("Usage:spark-submit producer1.py <input file>", file=sys.stderr)
exit(-1)
sc = SparkContext(appName="PythonRegression")
def sendkafka(messages):
## Set broker port
kafka = KafkaClient("localhost:9092")
producer = SimpleProducer(kafka, async=True, batch_send_every_n=5,
batch_send_every_t=10)
send_counts = 0
for message in messages:
try:
print(message)
## Set topic name and push messages to the Kafka Broker
yield producer.send_messages('test', message.encode('utf-8'))
except Exception, e:
print("Error: %s" % str(e))
else:
send_counts += 1
print("The count of prediction results which were sent IN THIS PARTITION
is %d.\n" % send_counts)
## Connect and read the file.
rawData = sc.textFile(sys.argv[1])
## Find and skip the first row
dataHeader = rawData.first()
data = rawData.filter(lambda x: x != dataHeader)
## Collect the RDDs.
sentRDD = data.mapPartitions(sendkafka)
sentRDD.collect()
## Stop file connection
sc.stop()
这是我的“消费者”python 编码
from __future__ import print_function
import sys
from pyspark import SparkContext
from pyspark.streaming import StreamingContext
from pyspark.streaming.kafka import KafkaUtils
if len(sys.argv) < 3:
print ("Program to pulls the messages from kafka brokers.")
print("Usage: consume.py <zk> <topic>", file=sys.stderr)
else:
## Flow
## Loads settings from system properties, for launching of spark-submit.
sc = SparkContext(appName="PythonStreamingKafkaWordCount")
## Create a StreamingContext using an existing SparkContext.
ssc = StreamingContext(sc, 10)
## Get everything after the python script name
zkQuorum, topic = sys.argv[1:]
## Create an input stream that pulls messages from Kafka Brokers.
kvs = KafkaUtils.createStream(ssc, zkQuorum, "spark-streaming-consumer",
{topic: 1})
##
lines = kvs.map(lambda x: x[1])
## Print the messages pulled from Kakfa Brokers
lines.pprint()
## Save the pulled messages as file
## lines.saveAsTextFiles("OutputA")
## Start receiving data and processing it
ssc.start()
## Allows the current process to wait for the termination of the context
ssc.awaitTermination()