|
|
马上注册,结交更多好友,享用更多功能,让你轻松玩转社区。
您需要 登录 才可以下载或查看,没有账号?立即注册
x
Python线程基础概念
Python中的线程是操作系统能够进行运算调度的最小单位,它被包含在进程之中,是进程中的实际运作单位。在Python中,我们主要通过threading模块来创建和管理线程。线程允许程序同时执行多个任务,提高程序的效率和响应速度。
Python中的线程由于GIL(全局解释器锁)的存在,实际上并不能实现真正的并行计算,但在I/O密集型任务中,线程仍然能够显著提高程序性能。理解线程的生命周期、状态转换以及资源管理是编写高效多线程应用的基础。
线程的创建和启动
在Python中,创建线程主要有两种方式:直接实例化threading.Thread类和继承threading.Thread类并重写run()方法。
方式一:直接实例化Thread类
- import threading
- import time
- def task():
- print("子线程开始执行")
- time.sleep(2)
- print("子线程执行结束")
- # 创建线程
- t = threading.Thread(target=task)
- # 启动线程
- t.start()
- # 主线程等待子线程结束
- t.join()
- print("主线程结束")
复制代码
方式二:继承Thread类
- import threading
- import time
- class MyThread(threading.Thread):
- def __init__(self, name):
- super().__init__()
- self.name = name
-
- def run(self):
- print(f"线程 {self.name} 开始执行")
- time.sleep(2)
- print(f"线程 {self.name} 执行结束")
- # 创建并启动线程
- t = MyThread("Thread-1")
- t.start()
- # 等待线程结束
- t.join()
- print("主线程结束")
复制代码
线程的正确释放方式
正确释放线程资源是避免内存泄漏的关键。Python中的线程一旦启动,就需要明确地管理其生命周期,确保线程完成任务后能够正确释放资源。
使用join()方法等待线程结束
join()方法是最基本的线程同步机制,它可以让主线程等待子线程执行完毕后再继续执行。
- import threading
- import time
- def worker():
- print("Worker线程开始工作")
- time.sleep(3)
- print("Worker线程结束工作")
- threads = []
- for i in range(5):
- t = threading.Thread(target=worker)
- threads.append(t)
- t.start()
- # 等待所有线程完成
- for t in threads:
- t.join()
- print("所有线程已完成")
复制代码
使用守护线程(Daemon Thread)
守护线程是一种在程序退出时会自动结束的线程,适合用于后台服务或监控任务。
- import threading
- import time
- def daemon_worker():
- print("守护线程开始工作")
- while True:
- print("守护线程正在运行...")
- time.sleep(1)
- print("守护线程结束工作") # 这行代码永远不会执行
- # 创建守护线程
- d = threading.Thread(target=daemon_worker)
- d.daemon = True # 设置为守护线程
- d.start()
- # 主线程
- time.sleep(3)
- print("主线程结束,程序退出,守护线程将被强制终止")
复制代码
使用Event控制线程退出
Event对象可以用来在线程间发送信号,控制线程的退出。
- import threading
- import time
- def worker(stop_event):
- print("Worker线程开始工作")
- while not stop_event.is_set():
- print("Worker线程正在运行...")
- time.sleep(1)
- print("Worker线程收到停止信号,准备退出")
- # 创建Event对象
- stop_event = threading.Event()
- # 创建并启动线程
- t = threading.Thread(target=worker, args=(stop_event,))
- t.start()
- # 主线程运行一段时间后发送停止信号
- time.sleep(3)
- stop_event.set()
- # 等待线程结束
- t.join()
- print("主线程结束")
复制代码
避免内存泄漏的技巧
在多线程应用中,内存泄漏是一个常见问题,通常由于线程未能正确释放资源或线程对象本身未被正确清理导致。
避免线程对象累积
确保不再需要的线程对象被正确清理,避免线程对象在程序中累积。
- import threading
- import time
- import weakref
- class ThreadManager:
- def __init__(self):
- self.threads = weakref.WeakSet() # 使用弱引用集合存储线程
-
- def start_thread(self, target, args=()):
- t = threading.Thread(target=target, args=args)
- self.threads.add(t)
- t.start()
- return t
-
- def cleanup(self):
- # 清理已结束的线程
- for t in list(self.threads):
- if not t.is_alive():
- self.threads.discard(t)
- def worker():
- print("Worker线程开始工作")
- time.sleep(2)
- print("Worker线程结束工作")
- # 使用线程管理器
- manager = ThreadManager()
- # 启动多个线程
- for i in range(5):
- manager.start_thread(worker)
- # 等待所有线程完成
- while any(t.is_alive() for t in manager.threads):
- time.sleep(0.5)
- manager.cleanup()
- print("所有线程已完成并清理")
复制代码
正确使用线程局部存储
线程局部存储(Thread-Local Storage)可以避免线程间数据共享导致的内存泄漏问题。
- import threading
- # 创建线程局部数据
- thread_local = threading.local()
- def worker():
- # 每个线程有自己的数据副本
- if not hasattr(thread_local, 'data'):
- thread_local.data = []
-
- thread_local.data.append(threading.current_thread().name)
- print(f"{threading.current_thread().name} 的数据: {thread_local.data}")
- threads = []
- for i in range(5):
- t = threading.Thread(target=worker)
- threads.append(t)
- t.start()
- for t in threads:
- t.join()
- print("主线程结束")
复制代码
避免循环引用
在线程间传递对象时,注意避免循环引用,这可能导致对象无法被垃圾回收。
- import threading
- import time
- import gc
- class Resource:
- def __init__(self, name):
- self.name = name
- self.cleanup_called = False
-
- def cleanup(self):
- self.cleanup_called = True
- print(f"资源 {self.name} 已清理")
-
- def __del__(self):
- if not self.cleanup_called:
- print(f"警告: 资源 {self.name} 未被正确清理")
- def worker_with_cycle(resource):
- # 创建循环引用
- resource.thread_ref = threading.current_thread()
- print(f"{threading.current_thread().name} 获取了资源 {resource.name}")
- time.sleep(1)
- # 不清理资源,制造内存泄漏
- def worker_without_cycle(resource):
- print(f"{threading.current_thread().name} 获取了资源 {resource.name}")
- time.sleep(1)
- # 正确清理资源
- resource.cleanup()
- # 测试循环引用情况
- print("=== 测试循环引用 ===")
- resource1 = Resource("Resource-1")
- t1 = threading.Thread(target=worker_with_cycle, args=(resource1,))
- t1.start()
- t1.join()
- # 强制垃圾回收
- gc.collect()
- del resource1
- gc.collect()
- # 测试无循环引用情况
- print("\n=== 测试无循环引用 ===")
- resource2 = Resource("Resource-2")
- t2 = threading.Thread(target=worker_without_cycle, args=(resource2,))
- t2.start()
- t2.join()
- # 强制垃圾回收
- gc.collect()
- del resource2
- gc.collect()
- print("主线程结束")
复制代码
避免死锁的方法
死锁是多线程编程中的常见问题,当两个或多个线程互相持有对方所需的资源,并且都在等待对方释放资源时,就会发生死锁。
避免嵌套锁
最简单的避免死锁的方法是避免嵌套锁,即一个线程已经持有一个锁时,不要再去获取另一个锁。
- import threading
- import time
- # 不好的做法:嵌套锁可能导致死锁
- lock1 = threading.Lock()
- lock2 = threading.Lock()
- def bad_worker1():
- with lock1:
- print("Worker1 获取了 lock1")
- time.sleep(0.1)
- with lock2:
- print("Worker1 获取了 lock2")
- def bad_worker2():
- with lock2:
- print("Worker2 获取了 lock2")
- time.sleep(0.1)
- with lock1:
- print("Worker2 获取了 lock1")
- # 好的做法:避免嵌套锁
- def good_worker1():
- with lock1:
- print("GoodWorker1 获取了 lock1")
- time.sleep(0.1)
- # 在释放lock1后再获取lock2
- with lock2:
- print("GoodWorker1 获取了 lock2")
- def good_worker2():
- with lock2:
- print("GoodWorker2 获取了 lock2")
- time.sleep(0.1)
- # 在释放lock2后再获取lock1
- with lock1:
- print("GoodWorker2 获取了 lock1")
- # 测试不好的做法(可能导致死锁)
- print("=== 测试不好的做法(可能导致死锁)===")
- try:
- t1 = threading.Thread(target=bad_worker1)
- t2 = threading.Thread(target=bad_worker2)
- t1.start()
- t2.start()
-
- # 设置超时,避免程序永远卡死
- t1.join(timeout=2)
- t2.join(timeout=2)
-
- if t1.is_alive() or t2.is_alive():
- print("检测到可能的死锁!")
- # 强制结束线程(注意:这不是一个好的做法,仅用于演示)
- # 实际应用中应该设计良好的锁策略,而不是强制结束线程
- except Exception as e:
- print(f"发生异常: {e}")
- # 测试好的做法
- print("\n=== 测试好的做法 ===")
- t3 = threading.Thread(target=good_worker1)
- t4 = threading.Thread(target=good_worker2)
- t3.start()
- t4.start()
- t3.join()
- t4.join()
- print("主线程结束")
复制代码
使用锁的超时机制
为锁设置超时可以避免线程无限期地等待资源,从而防止死锁。
- import threading
- import time
- lock1 = threading.Lock()
- lock2 = threading.Lock()
- def worker_with_timeout():
- # 尝试获取lock1,最多等待1秒
- if lock1.acquire(timeout=1):
- try:
- print("Worker 获取了 lock1")
- time.sleep(0.5)
-
- # 尝试获取lock2,最多等待1秒
- if lock2.acquire(timeout=1):
- try:
- print("Worker 获取了 lock2")
- time.sleep(0.5)
- finally:
- lock2.release()
- else:
- print("Worker 无法获取 lock2,超时")
- finally:
- lock1.release()
- else:
- print("Worker 无法获取 lock1,超时")
- # 测试带超时的锁
- t1 = threading.Thread(target=worker_with_timeout)
- t2 = threading.Thread(target=worker_with_timeout)
- t1.start()
- t2.start()
- t1.join()
- t2.join()
- print("主线程结束")
复制代码
使用RLock代替Lock
RLock(可重入锁)允许同一个线程多次获取同一个锁,而不会导致死锁。
- import threading
- # 使用Lock可能导致死锁
- lock = threading.Lock()
- def recursive_function_with_lock(n):
- if n <= 0:
- return
-
- with lock:
- print(f"递归深度: {n}")
- recursive_function_with_lock(n - 1)
- # 使用RLock避免死锁
- rlock = threading.RLock()
- def recursive_function_with_rlock(n):
- if n <= 0:
- return
-
- with rlock:
- print(f"递归深度: {n}")
- recursive_function_with_rlock(n - 1)
- # 测试Lock
- print("=== 测试Lock(可能导致死锁)===")
- try:
- recursive_function_with_lock(3)
- except Exception as e:
- print(f"发生异常: {e}")
- # 测试RLock
- print("\n=== 测试RLock ===")
- recursive_function_with_rlock(3)
- print("主线程结束")
复制代码
线程池的使用和管理
线程池是一种多线程处理形式,处理过程中将任务添加到队列,然后在创建线程后自动启动这些任务。线程池可以有效地管理线程资源,避免频繁创建和销毁线程带来的开销。
使用ThreadPoolExecutor
concurrent.futures.ThreadPoolExecutor是Python标准库中提供的线程池实现。
- import concurrent.futures
- import time
- import threading
- def worker(task_id):
- thread_name = threading.current_thread().name
- print(f"任务 {task_id} 由线程 {thread_name} 执行")
- time.sleep(1)
- return f"任务 {task_id} 完成"
- # 创建线程池
- with concurrent.futures.ThreadPoolExecutor(max_workers=3) as executor:
- # 提交任务到线程池
- futures = [executor.submit(worker, i) for i in range(5)]
-
- # 获取任务结果
- for future in concurrent.futures.as_completed(futures):
- print(future.result())
- print("所有任务已完成")
复制代码
使用Queue实现自定义线程池
我们也可以使用queue.Queue来实现自定义的线程池。
- import threading
- import queue
- import time
- class ThreadPool:
- def __init__(self, num_threads):
- self.tasks = queue.Queue()
- self.threads = []
- self.stop_event = threading.Event()
-
- # 创建工作线程
- for _ in range(num_threads):
- thread = threading.Thread(target=self.worker)
- thread.daemon = True # 设置为守护线程
- thread.start()
- self.threads.append(thread)
-
- def worker(self):
- while not self.stop_event.is_set():
- try:
- # 从队列获取任务,设置超时以避免永久阻塞
- task, args, kwargs = self.tasks.get(timeout=0.1)
- try:
- task(*args, **kwargs)
- except Exception as e:
- print(f"任务执行出错: {e}")
- finally:
- self.tasks.task_done()
- except queue.Empty:
- continue
-
- def add_task(self, task, *args, **kwargs):
- self.tasks.put((task, args, kwargs))
-
- def wait_completion(self):
- self.tasks.join()
-
- def stop(self):
- self.stop_event.set()
- for thread in self.threads:
- thread.join()
- def sample_task(task_id):
- thread_name = threading.current_thread().name
- print(f"任务 {task_id} 由线程 {thread_name} 执行")
- time.sleep(1)
- print(f"任务 {task_id} 完成")
- # 使用自定义线程池
- pool = ThreadPool(3)
- # 添加任务
- for i in range(5):
- pool.add_task(sample_task, i)
- # 等待所有任务完成
- pool.wait_completion()
- # 停止线程池
- pool.stop()
- print("所有任务已完成")
复制代码
线程池的正确关闭
正确关闭线程池是避免资源泄漏的重要步骤。
- import concurrent.futures
- import time
- def long_running_task(task_id):
- print(f"任务 {task_id} 开始")
- time.sleep(2)
- print(f"任务 {task_id} 完成")
- return f"任务 {task_id} 的结果"
- # 创建线程池
- executor = concurrent.futures.ThreadPoolExecutor(max_workers=3)
- # 提交任务
- futures = [executor.submit(long_running_task, i) for i in range(5)]
- # 尝试优雅地关闭线程池
- print("尝试优雅关闭线程池...")
- executor.shutdown(wait=False) # 不等待任务完成
- # 等待一段时间让部分任务完成
- time.sleep(1)
- # 取消未开始的任务
- for future in futures:
- if not future.done():
- print("取消未完成的任务")
- future.cancel()
- # 强制关闭线程池(注意:这不是一个好的做法,仅用于演示)
- # 实际应用中应该设计良好的任务取消机制
- print("强制关闭线程池")
- executor.shutdown(wait=True)
- print("线程池已关闭")
复制代码
高级线程同步机制
除了基本的锁机制,Python还提供了更高级的线程同步工具,如条件变量、信号量和屏障等。
使用Condition实现复杂的同步
Condition对象允许一个或多个线程等待,直到被另一个线程通知。
- import threading
- import time
- import random
- class ProducerConsumer:
- def __init__(self, buffer_size=5):
- self.buffer = []
- self.buffer_size = buffer_size
- self.condition = threading.Condition()
-
- def produce(self, item):
- with self.condition:
- while len(self.buffer) >= self.buffer_size:
- print("缓冲区已满,生产者等待")
- self.condition.wait()
-
- self.buffer.append(item)
- print(f"生产了: {item}, 缓冲区: {self.buffer}")
- self.condition.notify_all() # 通知所有等待的消费者
-
- def consume(self):
- with self.condition:
- while not self.buffer:
- print("缓冲区为空,消费者等待")
- self.condition.wait()
-
- item = self.buffer.pop(0)
- print(f"消费了: {item}, 缓冲区: {self.buffer}")
- self.condition.notify_all() # 通知所有等待的生产者
- return item
- def producer(pc, items):
- for item in items:
- time.sleep(random.random()) # 模拟生产耗时
- pc.produce(item)
- def consumer(pc, count):
- for _ in range(count):
- time.sleep(random.random()) # 模拟消费耗时
- item = pc.consume()
- # 创建生产者消费者模型
- pc = ProducerConsumer()
- # 创建生产者和消费者线程
- items = [f"Item-{i}" for i in range(10)]
- producer_thread = threading.Thread(target=producer, args=(pc, items))
- consumer_thread = threading.Thread(target=consumer, args=(pc, len(items)))
- # 启动线程
- producer_thread.start()
- consumer_thread.start()
- # 等待线程完成
- producer_thread.join()
- consumer_thread.join()
- print("生产者和消费者已完成")
复制代码
使用Semaphore控制资源访问
Semaphore用于控制对有限资源的访问。
- import threading
- import time
- import random
- class ResourcePool:
- def __init__(self, size):
- self.semaphore = threading.Semaphore(size)
- self.resources = [f"Resource-{i}" for i in range(size)]
-
- def acquire(self):
- self.semaphore.acquire()
- # 获取可用资源
- resource = self.resources.pop()
- print(f"获取资源: {resource}")
- return resource
-
- def release(self, resource):
- # 释放资源
- self.resources.append(resource)
- print(f"释放资源: {resource}")
- self.semaphore.release()
- def worker(pool, worker_id):
- print(f"Worker {worker_id} 尝试获取资源")
- resource = pool.acquire()
-
- # 使用资源
- time.sleep(random.random())
-
- # 释放资源
- pool.release(resource)
- print(f"Worker {worker_id} 完成工作")
- # 创建资源池
- pool = ResourcePool(3)
- # 创建工作线程
- workers = []
- for i in range(8):
- worker_thread = threading.Thread(target=worker, args=(pool, i))
- workers.append(worker_thread)
- worker_thread.start()
- # 等待所有工作线程完成
- for worker_thread in workers:
- worker_thread.join()
- print("所有工作已完成")
复制代码
使用Barrier同步多个线程
Barrier用于同步多个线程,直到所有线程都到达某个点。
- import threading
- import time
- import random
- def worker(barrier, worker_id):
- print(f"Worker {worker_id} 开始第一阶段")
- time.sleep(random.random())
- print(f"Worker {worker_id} 完成第一阶段,等待其他线程")
-
- # 等待所有线程到达屏障
- barrier.wait()
-
- print(f"Worker {worker_id} 开始第二阶段")
- time.sleep(random.random())
- print(f"Worker {worker_id} 完成第二阶段")
- # 创建屏障,等待3个线程
- barrier = threading.Barrier(3)
- # 创建工作线程
- workers = []
- for i in range(3):
- worker_thread = threading.Thread(target=worker, args=(barrier, i))
- workers.append(worker_thread)
- worker_thread.start()
- # 等待所有工作线程完成
- for worker_thread in workers:
- worker_thread.join()
- print("所有工作已完成")
复制代码
实战案例和最佳实践
让我们通过一个实际案例来综合应用前面介绍的技术。
实战案例:多线程Web爬虫
下面是一个使用多线程实现的Web爬虫示例,它包含了线程池、任务队列、结果收集和优雅关闭等功能。
- import threading
- import queue
- import time
- import requests
- from bs4 import BeautifulSoup
- from urllib.parse import urljoin, urlparse
- import concurrent.futures
- class WebCrawler:
- def __init__(self, max_threads=5, max_pages=50):
- self.max_threads = max_threads
- self.max_pages = max_pages
- self.url_queue = queue.Queue()
- self.visited_urls = set()
- self.lock = threading.Lock()
- self.stop_event = threading.Event()
- self.pages_crawled = 0
-
- def add_url(self, url):
- with self.lock:
- if url not in self.visited_urls and self.pages_crawled < self.max_pages:
- self.visited_urls.add(url)
- self.url_queue.put(url)
- return True
- return False
-
- def get_page(self, url):
- try:
- response = requests.get(url, timeout=5)
- if response.status_code == 200:
- return response.text
- except Exception as e:
- print(f"获取页面 {url} 时出错: {e}")
- return None
-
- def parse_links(self, html, base_url):
- soup = BeautifulSoup(html, 'html.parser')
- links = []
- for link in soup.find_all('a', href=True):
- href = link['href']
- full_url = urljoin(base_url, href)
- # 确保URL是有效的HTTP链接
- parsed = urlparse(full_url)
- if parsed.scheme in ('http', 'https'):
- links.append(full_url)
- return links
-
- def worker(self):
- while not self.stop_event.is_set():
- try:
- # 从队列获取URL,设置超时以避免永久阻塞
- url = self.url_queue.get(timeout=0.5)
-
- print(f"爬取: {url}")
- html = self.get_page(url)
-
- if html:
- # 解析页面中的链接
- links = self.parse_links(html, url)
-
- # 将新链接添加到队列
- for link in links:
- self.add_url(link)
-
- with self.lock:
- self.pages_crawled += 1
- print(f"已爬取 {self.pages_crawled}/{self.max_pages} 页")
-
- self.url_queue.task_done()
-
- except queue.Empty:
- continue
- except Exception as e:
- print(f"工作线程出错: {e}")
-
- def crawl(self, start_url):
- # 添加起始URL
- self.add_url(start_url)
-
- # 创建工作线程
- threads = []
- for _ in range(self.max_threads):
- thread = threading.Thread(target=self.worker)
- thread.daemon = True
- thread.start()
- threads.append(thread)
-
- # 等待所有任务完成
- try:
- while self.pages_crawled < self.max_pages and not self.url_queue.empty():
- time.sleep(0.1)
- except KeyboardInterrupt:
- print("收到中断信号,正在停止爬虫...")
- self.stop_event.set()
-
- # 等待队列中的任务完成
- self.url_queue.join()
-
- # 停止工作线程
- self.stop_event.set()
- for thread in threads:
- thread.join()
-
- print(f"爬取完成,共爬取 {self.pages_crawled} 页")
- # 使用爬虫
- if __name__ == "__main__":
- crawler = WebCrawler(max_threads=5, max_pages=20)
- crawler.crawl("https://example.com")
复制代码
最佳实践总结
1. 合理设置线程数量:线程数量不是越多越好,通常设置为CPU核心数的2-5倍。对于I/O密集型任务,可以适当增加线程数量。
2. 使用线程池:避免频繁创建和销毁线程,使用线程池可以重用线程,提高性能。
3. 避免共享状态:尽量减少线程间的共享状态,使用线程局部存储或消息传递代替共享内存。
4. 正确使用锁:避免嵌套锁,为锁设置超时,优先使用RLock代替Lock。
5. 优雅地关闭线程:使用事件或标志位通知线程退出,避免强制终止线程。
6. 处理异常:确保线程中的异常被正确捕获和处理,避免线程静默失败。
7. 资源管理:确保线程中使用的资源(如文件、网络连接等)被正确释放,避免资源泄漏。
8. 避免死锁:按照固定顺序获取锁,使用锁的超时机制,避免循环等待。
9. 使用高级同步工具:根据场景选择合适的同步工具,如Condition、Semaphore、Barrier等。
10. 监控和调试:使用日志和监控工具跟踪线程的执行情况,便于调试和优化。
合理设置线程数量:线程数量不是越多越好,通常设置为CPU核心数的2-5倍。对于I/O密集型任务,可以适当增加线程数量。
使用线程池:避免频繁创建和销毁线程,使用线程池可以重用线程,提高性能。
避免共享状态:尽量减少线程间的共享状态,使用线程局部存储或消息传递代替共享内存。
正确使用锁:避免嵌套锁,为锁设置超时,优先使用RLock代替Lock。
优雅地关闭线程:使用事件或标志位通知线程退出,避免强制终止线程。
处理异常:确保线程中的异常被正确捕获和处理,避免线程静默失败。
资源管理:确保线程中使用的资源(如文件、网络连接等)被正确释放,避免资源泄漏。
避免死锁:按照固定顺序获取锁,使用锁的超时机制,避免循环等待。
使用高级同步工具:根据场景选择合适的同步工具,如Condition、Semaphore、Barrier等。
监控和调试:使用日志和监控工具跟踪线程的执行情况,便于调试和优化。
性能优化技巧
1. 使用concurrent.futures:Python标准库中的concurrent.futures模块提供了高级的线程池接口,简化了多线程编程。
- import concurrent.futures
- import time
- def cpu_bound_task(n):
- return sum(i * i for i in range(n))
- def io_bound_task(url):
- import requests
- response = requests.get(url)
- return len(response.content)
- # 使用ThreadPoolExecutor处理I/O密集型任务
- urls = ["https://example.com"] * 10
- with concurrent.futures.ThreadPoolExecutor(max_workers=5) as executor:
- start_time = time.time()
- futures = [executor.submit(io_bound_task, url) for url in urls]
- results = [future.result() for future in concurrent.futures.as_completed(futures)]
- print(f"I/O密集型任务耗时: {time.time() - start_time} 秒")
- # 注意:对于CPU密集型任务,Python的线程由于GIL的限制,可能不会提高性能
- # 这种情况下应考虑使用多进程(multiprocessing)或异步编程(asyncio)
- numbers = [100000] * 10
- with concurrent.futures.ThreadPoolExecutor(max_workers=5) as executor:
- start_time = time.time()
- futures = [executor.submit(cpu_bound_task, n) for n in numbers]
- results = [future.result() for future in concurrent.futures.as_completed(futures)]
- print(f"CPU密集型任务耗时: {time.time() - start_time} 秒")
复制代码
1. 使用队列进行线程间通信:队列是线程安全的,适合用于线程间传递数据。
- import threading
- import queue
- import time
- def producer(q, items):
- for item in items:
- time.sleep(0.1) # 模拟生产耗时
- q.put(item)
- print(f"生产了: {item}")
- q.put(None) # 发送结束信号
- def consumer(q):
- while True:
- item = q.get()
- if item is None: # 收到结束信号
- q.task_done()
- break
- time.sleep(0.2) # 模拟消费耗时
- print(f"消费了: {item}")
- q.task_done()
- # 创建队列
- q = queue.Queue()
- # 创建生产者和消费者线程
- items = [f"Item-{i}" for i in range(10)]
- producer_thread = threading.Thread(target=producer, args=(q, items))
- consumer_thread = threading.Thread(target=consumer, args=(q,))
- # 启动线程
- producer_thread.start()
- consumer_thread.start()
- # 等待线程完成
- producer_thread.join()
- consumer_thread.join()
- print("生产者和消费者已完成")
复制代码
1. 使用线程局部存储避免竞争:线程局部存储可以避免线程间的数据竞争,提高性能。
- import threading
- import time
- # 全局变量
- global_data = {"value": 0}
- # 线程局部存储
- thread_local = threading.local()
- def worker_with_global():
- for _ in range(100000):
- global_data["value"] += 1
- def worker_with_local():
- # 初始化线程局部数据
- if not hasattr(thread_local, "value"):
- thread_local.value = 0
-
- for _ in range(100000):
- thread_local.value += 1
-
- # 将结果合并到全局数据
- with threading.Lock():
- global_data["value"] += thread_local.value
- # 测试使用全局变量
- print("=== 测试使用全局变量 ===")
- global_data["value"] = 0
- threads = []
- start_time = time.time()
- for _ in range(5):
- t = threading.Thread(target=worker_with_global)
- threads.append(t)
- t.start()
- for t in threads:
- t.join()
- print(f"使用全局变量的结果: {global_data['value']}, 耗时: {time.time() - start_time} 秒")
- # 测试使用线程局部存储
- print("\n=== 测试使用线程局部存储 ===")
- global_data["value"] = 0
- threads = []
- start_time = time.time()
- for _ in range(5):
- t = threading.Thread(target=worker_with_local)
- threads.append(t)
- t.start()
- for t in threads:
- t.join()
- print(f"使用线程局部存储的结果: {global_data['value']}, 耗时: {time.time() - start_time} 秒")
复制代码
总结
Python线程是提高程序并发性能的重要工具,但正确管理线程资源、避免内存泄漏和死锁是编写高效稳定多线程应用的关键。本文从线程基础概念入手,详细介绍了线程的创建、释放、资源管理、死锁避免、线程池使用和高级同步机制等内容,并通过实战案例和最佳实践,帮助读者掌握Python线程编程的精髓。
在实际应用中,应根据任务类型(I/O密集型或CPU密集型)选择合适的并发模型,合理设置线程数量,使用线程池管理线程资源,正确使用同步工具避免竞争条件和死锁,并确保线程和资源被正确释放。通过遵循这些原则和技巧,可以编写出高效、稳定的多线程应用。
希望本文能够帮助读者深入理解Python线程编程,并在实际项目中应用这些技术,提高程序的并发性能和稳定性。
版权声明
1、转载或引用本网站内容(Python线程释放实战技巧详解从入门到精通教你如何正确管理线程资源避免内存泄漏和死锁让你的多线程应用更加高效稳定)须注明原网址及作者(威震华夏关云长),并标明本网站网址(https://pixtech.cc/)。
2、对于不当转载或引用本网站内容而引起的民事纷争、行政处理或其他损失,本网站不承担责任。
3、对不遵守本声明或其他违法、恶意使用本网站内容者,本网站保留追究其法律责任的权利。
本文地址: https://pixtech.cc/thread-39479-1-1.html
|
|