Development of an internal social media platform with personalised dashboards for students
You can not select more than 25 topics Topics must start with a letter or number, can include dashes ('-') and can be up to 35 characters long.

PKG-INFO 27KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792
  1. Metadata-Version: 1.2
  2. Name: billiard
  3. Version: 3.3.0.23
  4. Summary: Python multiprocessing fork with improvements and bugfixes
  5. Home-page: http://github.com/celery/billiard
  6. Author: R Oudkerk / Python Software Foundation
  7. Author-email: python-dev@python.org
  8. Maintainer: Ask Solem
  9. Maintainer-email: ask@celeryproject.org
  10. License: BSD
  11. Description: ========
  12. billiard
  13. ========
  14. :version: 3.3.0.23
  15. About
  16. -----
  17. `billiard` is a fork of the Python 2.7 `multiprocessing <http://docs.python.org/library/multiprocessing.html>`_
  18. package. The multiprocessing package itself is a renamed and updated version of
  19. R Oudkerk's `pyprocessing <http://pypi.python.org/pypi/processing/>`_ package.
  20. This standalone variant is intended to be compatible with Python 2.4 and 2.5,
  21. and will draw it's fixes/improvements from python-trunk.
  22. - This package would not be possible if not for the contributions of not only
  23. the current maintainers but all of the contributors to the original pyprocessing
  24. package listed `here <http://pyprocessing.berlios.de/doc/THANKS.html>`_
  25. - Also it is a fork of the multiprocessin backport package by Christian Heims.
  26. - It includes the no-execv patch contributed by R. Oudkerk.
  27. - And the Pool improvements previously located in `Celery`_.
  28. .. _`Celery`: http://celeryproject.org
  29. Bug reporting
  30. -------------
  31. Please report bugs related to multiprocessing at the
  32. `Python bug tracker <http://bugs.python.org/>`_. Issues related to billiard
  33. should be reported at http://github.com/celery/billiard/issues.
  34. .. image:: https://d2weczhvl823v0.cloudfront.net/celery/billiard/trend.png
  35. :alt: Bitdeli badge
  36. :target: https://bitdeli.com/free
  37. ===========
  38. Changes
  39. ===========
  40. 3.3.0.23 - 2016-03-03
  41. ---------------------
  42. - ExceptionInfo: Adds tb_lasti and other missing traceback fields
  43. (Issue #180).
  44. - monotonic: Now makes sure ctypes is available.
  45. - PipeConnection: Make sure the pipe is not closed multiple times.
  46. 3.3.0.22 - 2015-12-08
  47. ---------------------
  48. - Wheel packages for Windows now available.
  49. 3.3.0.21 - 2015-10-26
  50. ---------------------
  51. - Pool: Fixed semaphore error on Python3.
  52. - Fixed libSystem error on OS X El Capitan.
  53. 3.3.0.20 - 2015-04-17
  54. ---------------------
  55. - Pool: Timeouts will attempt to send SIGKILL, but this signal
  56. does not exist on Windows. Replaced with SIGTERM.
  57. 3.3.0.19 - 2014-10-13
  58. ---------------------
  59. - Pool: Exceptions in user timeout callbacks are now logged instead
  60. of crashing the pool.
  61. Contributed by Pierre Fersing.
  62. - Pool: Exit codes in errors were improperly being represented as signals.
  63. - Pool: ``.map``. and ``.imap`` now working again.
  64. - Now builds on FreeBSD 10.
  65. Contributed by Michael Fladischer.
  66. 3.3.0.18 - 2014-06-20
  67. ---------------------
  68. - Now compiles on GNU/kFreeBSD
  69. Contributed by Michael Fladischer.
  70. - Pool: `AF_PIPE` address fixed so that it works on recent Windows versions
  71. in combination with Python 2.7.7.
  72. Fix contributed by Joshua Tacoma.
  73. - Pool: Fix for `Supervisor object has no attribute _children` error.
  74. Fix contributed by Andres Riancho.
  75. - Pool: Fixed bug with human_status(None).
  76. - Pool: shrink did not work properly if asked to remove more than 1 process.
  77. 3.3.0.17 - 2014-04-16
  78. ---------------------
  79. - Fixes SemLock on Python 3.4 (Issue #107) when using
  80. ``forking_enable(False)``.
  81. - Pool: Include more useful exitcode information when processes exit.
  82. 3.3.0.16 - 2014-02-11
  83. ---------------------
  84. - Previous release was missing the billiard.py3 package from MANIFEST
  85. so the installation would not work on Python 3.
  86. 3.3.0.15 - 2014-02-10
  87. ---------------------
  88. - Pool: Fixed "cannot join process not started" error.
  89. - Now uses billiard.py2 and billiard.py3 specific packages that are installed
  90. depending on the python version used.
  91. This way the installation will not import version specific modules (and
  92. possibly crash).
  93. 3.3.0.14 - 2014-01-17
  94. ---------------------
  95. - Fixed problem with our backwards compatible ``bytes`` wrapper
  96. (Issue #103).
  97. - No longer expects frozen applications to have a valid ``__file__``
  98. attribute.
  99. Fix contributed by George Sibble.
  100. 3.3.0.13 - 2013-12-13
  101. ---------------------
  102. - Fixes compatability with Python < 2.7.6
  103. - No longer attempts to handle ``SIGBUS``
  104. Contributed by Vishal Vatsa.
  105. - Non-thread based pool now only handles signals:
  106. ``SIGHUP``, ``SIGQUIT``, ``SIGTERM``, ``SIGUSR1``,
  107. ``SIGUSR2``.
  108. - setup.py: Only show compilation warning for build related commands.
  109. 3.3.0.12 - 2013-12-09
  110. ---------------------
  111. - Fixed installation for Python 3.
  112. Contributed by Rickert Mulder.
  113. - Pool: Fixed bug with maxtasksperchild.
  114. Fix contributed by Ionel Cristian Maries.
  115. - Pool: Fixed bug in maintain_pool.
  116. 3.3.0.11 - 2013-12-03
  117. ---------------------
  118. - Fixed Unicode error when installing the distribution (Issue #89).
  119. - Daemonic processes are now allowed to have children.
  120. But note that it will not be possible to automatically
  121. terminate them when the process exits.
  122. See discussion at https://github.com/celery/celery/issues/1709
  123. - Pool: Would not always be able to detect that a process exited.
  124. 3.3.0.10 - 2013-12-02
  125. ---------------------
  126. - Windows: Fixed problem with missing ``WAITABANDONED_0``
  127. Fix contributed by Matthias Wagner
  128. - Windows: PipeConnection can now be inherited.
  129. Fix contributed by Matthias Wagner
  130. 3.3.0.9 - 2013-12-02
  131. --------------------
  132. - Temporary workaround for Celery maxtasksperchild issue.
  133. Fix contributed by Ionel Cristian Maries.
  134. 3.3.0.8 - 2013-11-21
  135. --------------------
  136. - Now also sets ``multiprocessing.current_process`` for compatibility
  137. with loggings ``processName`` field.
  138. 3.3.0.7 - 2013-11-15
  139. --------------------
  140. - Fixed compatibility with PyPy 2.1 + 2.2.
  141. - Fixed problem in pypy detection.
  142. Fix contributed by Tin Tvrtkovic.
  143. - Now uses ``ctypes.find_library`` instead of hardcoded path to find
  144. the OS X CoreServices framework.
  145. Fix contributed by Moritz Kassner.
  146. 3.3.0.6 - 2013-11-12
  147. --------------------
  148. - Now works without C extension again.
  149. - New ``_billiard.read(fd, buffer, [len, ])`` function
  150. implements os.read with buffer support (new buffer API)
  151. - New pure-python implementation of ``Connection.send_offset``.
  152. 3.3.0.5 - 2013-11-11
  153. --------------------
  154. - All platforms except for Windows/PyPy/Jython now requires the C extension.
  155. 3.3.0.4 - 2013-11-11
  156. --------------------
  157. - Fixed problem with Python3 and setblocking.
  158. 3.3.0.3 - 2013-11-09
  159. --------------------
  160. - Now works on Windows again.
  161. 3.3.0.2 - 2013-11-08
  162. --------------------
  163. - ApplyResult.terminate() may be set to signify that the job
  164. must not be executed. It can be used in combination with
  165. Pool.terminate_job.
  166. - Pipe/_SimpleQueue: Now supports rnonblock/wnonblock arguments
  167. to set the read or write end of the pipe to be nonblocking.
  168. - Pool: Log message included exception info but exception happened
  169. in another process so the resulting traceback was wrong.
  170. - Pool: Worker process can now prepare results before they are sent
  171. back to the main process (using ``Worker.prepare_result``).
  172. 3.3.0.1 - 2013-11-04
  173. --------------------
  174. - Pool: New ``correlation_id`` argument to ``apply_async`` can be
  175. used to set a related id for the ``ApplyResult`` object returned:
  176. >>> r = pool.apply_async(target, args, kwargs, correlation_id='foo')
  177. >>> r.correlation_id
  178. 'foo'
  179. - Pool: New callback `on_process_exit` is called when a pool
  180. process exits, with signature ``(pid, exitcode)``.
  181. Contributed by Daniel M. Taub.
  182. - Pool: Improved the too many restarts detection.
  183. 3.3.0.0 - 2013-10-14
  184. --------------------
  185. - Dual code base now runs on Python 2.6+ and Python 3.
  186. - No longer compatible with Python 2.5
  187. - Includes many changes from multiprocessing in 3.4.
  188. - Now uses ``time.monotonic`` when available, also including
  189. fallback implementations for Linux and OS X.
  190. - No longer cleans up after receiving SIGILL, SIGSEGV or SIGFPE
  191. Contributed by Kevin Blackham
  192. - ``Finalize`` and ``register_after_fork`` is now aliases to multiprocessing.
  193. It's better to import these from multiprocessing directly now
  194. so that there aren't multiple registries.
  195. - New `billiard.queues._SimpleQueue` that does not use semaphores.
  196. - Pool: Can now be extended to support using multiple IPC queues.
  197. - Pool: Can now use async I/O to write to pool IPC queues.
  198. - Pool: New ``Worker.on_loop_stop`` handler can be used to add actions
  199. at pool worker process shutdown.
  200. Note that, like all finalization handlers, there is no guarantee that
  201. this will be executed.
  202. Contributed by dmtaub.
  203. 2.7.3.30 - 2013-06-28
  204. ---------------------
  205. - Fixed ImportError in billiard._ext
  206. 2.7.3.29 - 2013-06-28
  207. ---------------------
  208. - Compilation: Fixed improper handling of HAVE_SEM_OPEN (Issue #55)
  209. Fix contributed by Krzysztof Jagiello.
  210. - Process now releases logging locks after fork.
  211. This previously happened in Pool, but it was done too late
  212. as processes logs when they bootstrap.
  213. - Pool.terminate_job now ignores `No such process` errors.
  214. - billiard.Pool entrypoint did not support new arguments
  215. to billiard.pool.Pool
  216. - Connection inbound buffer size increased from 1kb to 128kb.
  217. - C extension cleaned up by properly adding a namespace to symbols.
  218. - _exit_function now works even if thread wakes up after gc collect.
  219. 2.7.3.28 - 2013-04-16
  220. ---------------------
  221. - Pool: Fixed regression that disabled the deadlock
  222. fix in 2.7.3.24
  223. - Pool: RestartFreqExceeded could be raised prematurely.
  224. - Process: Include pid in startup and process INFO logs.
  225. 2.7.3.27 - 2013-04-12
  226. ---------------------
  227. - Manager now works again.
  228. - Python 3 fixes for billiard.connection.
  229. - Fixed invalid argument bug when running on Python 3.3
  230. Fix contributed by Nathan Wan.
  231. - Ignore OSError when setting up signal handlers.
  232. 2.7.3.26 - 2013-04-09
  233. ---------------------
  234. - Pool: Child processes must ignore SIGINT.
  235. 2.7.3.25 - 2013-04-09
  236. ---------------------
  237. - Pool: 2.7.3.24 broke support for subprocesses (Issue #48).
  238. Signals that should be ignored were instead handled
  239. by terminating.
  240. 2.7.3.24 - 2013-04-08
  241. ---------------------
  242. - Pool: Make sure finally blocks are called when process exits
  243. due to a signal.
  244. This fixes a deadlock problem when the process is killed
  245. while having acquired the shared semaphore. However, this solution
  246. does not protect against the processes being killed, a more elaborate
  247. solution is required for that. Hopefully this will be fixed soon in a
  248. later version.
  249. - Pool: Can now use GDB to debug pool child processes.
  250. - Fixes Python 3 compatibility problems.
  251. Contributed by Albertas Agejevas.
  252. 2.7.3.23 - 2013-03-22
  253. ---------------------
  254. - Windows: Now catches SystemExit from setuptools while trying to build
  255. the C extension (Issue #41).
  256. 2.7.3.22 - 2013-03-08
  257. ---------------------
  258. - Pool: apply_async now supports a ``callbacks_propagate`` keyword
  259. argument that can be a tuple of exceptions to propagate in callbacks.
  260. (callback, errback, accept_callback, timeout_callback).
  261. - Errors are no longer logged for OK and recycle exit codes.
  262. This would cause normal maxtasksperchild recycled process
  263. to log an error.
  264. - Fixed Python 2.5 compatibility problem (Issue #33).
  265. - FreeBSD: Compilation now disables semaphores if Python was built
  266. without it (Issue #40).
  267. Contributed by William Grzybowski
  268. 2.7.3.21 - 2013-02-11
  269. ---------------------
  270. - Fixed typo EX_REUSE -> EX_RECYCLE
  271. - Code now conforms to new pep8.py rules.
  272. 2.7.3.20 - 2013-02-08
  273. ---------------------
  274. - Pool: Disable restart limit if maxR is not set.
  275. - Pool: Now uses os.kill instead of signal.signal.
  276. Contributed by Lukasz Langa
  277. - Fixed name error in process.py
  278. - Pool: ApplyResult.get now properly raises exceptions.
  279. Fix contributed by xentac.
  280. 2.7.3.19 - 2012-11-30
  281. ---------------------
  282. - Fixes problem at shutdown when gc has collected symbols.
  283. - Pool now always uses _kill for Py2.5 compatibility on Windows (Issue #32).
  284. - Fixes Python 3 compatibility issues
  285. 2.7.3.18 - 2012-11-05
  286. ---------------------
  287. - [Pool] Fix for check_timeouts if not set.
  288. Fix contributed by Dmitry Sukhov
  289. - Fixed pickle problem with Traceback.
  290. Code.frame.__loader__ is now ignored as it may be set to
  291. an unpickleable object.
  292. - The Django old-layout warning was always showing.
  293. 2.7.3.17 - 2012-09-26
  294. ---------------------
  295. - Fixes typo
  296. 2.7.3.16 - 2012-09-26
  297. ---------------------
  298. - Windows: Fixes for SemLock._rebuild (Issue #24).
  299. - Pool: Job terminated with terminate_job now raises
  300. billiard.exceptions.Terminated.
  301. 2.7.3.15 - 2012-09-21
  302. ---------------------
  303. - Windows: Fixes unpickling of SemLock when using fallback.
  304. - Windows: Fixes installation when no C compiler.
  305. 2.7.3.14 - 2012-09-20
  306. ---------------------
  307. - Installation now works again for Python 3.
  308. 2.7.3.13 - 2012-09-14
  309. ---------------------
  310. - Merged with Python trunk (many authors, many fixes: see Python changelog in
  311. trunk).
  312. - Using execv now also works with older Django projects using setup_environ
  313. (Issue #10).
  314. - Billiard now installs with a warning that the C extension could not be built
  315. if a compiler is not installed or the build fails in some other way.
  316. It really is recommended to have the C extension installed when running
  317. with force execv, but this change also makes it easier to install.
  318. - Pool: Hard timeouts now sends KILL shortly after TERM so that C extensions
  319. cannot block the signal.
  320. Python signal handlers are called in the interpreter, so they cannot
  321. be called while a C extension is blocking the interpreter from running.
  322. - Now uses a timeout value for Thread.join that doesn't exceed the maximum
  323. on some platforms.
  324. - Fixed bug in the SemLock fallback used when C extensions not installed.
  325. Fix contributed by Mher Movsisyan.
  326. - Pool: Now sets a Process.index attribute for every process in the pool.
  327. This number will always be between 0 and concurrency-1, and
  328. can be used to e.g. create a logfile for each process in the pool
  329. without creating a new logfile whenever a process is replaced.
  330. 2.7.3.12 - 2012-08-05
  331. ---------------------
  332. - Fixed Python 2.5 compatibility issue.
  333. - New Pool.terminate_job(pid) to terminate a job without raising WorkerLostError
  334. 2.7.3.11 - 2012-08-01
  335. ---------------------
  336. - Adds support for FreeBSD 7+
  337. Fix contributed by koobs.
  338. - Pool: New argument ``allow_restart`` is now required to enable
  339. the pool process sentinel that is required to restart the pool.
  340. It's disabled by default, which reduces the number of file
  341. descriptors/semaphores required to run the pool.
  342. - Pool: Now emits a warning if a worker process exited with error-code.
  343. But not if the error code is 155, which is now returned if the worker
  344. process was recycled (maxtasksperchild).
  345. - Python 3 compatibility fixes.
  346. - Python 2.5 compatibility fixes.
  347. 2.7.3.10 - 2012-06-26
  348. ---------------------
  349. - The ``TimeLimitExceeded`` exception string representation
  350. only included the seconds as a number, it now gives a more human
  351. friendly description.
  352. - Fixed typo in ``LaxBoundedSemaphore.shrink``.
  353. - Pool: ``ResultHandler.handle_event`` no longer requires
  354. any arguments.
  355. - setup.py bdist now works
  356. 2.7.3.9 - 2012-06-03
  357. --------------------
  358. - Environment variable ``MP_MAIN_FILE`` envvar is now set to
  359. the path of the ``__main__`` module when execv is enabled.
  360. - Pool: Errors occurring in the TaskHandler are now reported.
  361. 2.7.3.8 - 2012-06-01
  362. --------------------
  363. - Can now be installed on Py 3.2
  364. - Issue #12091: simplify ApplyResult and MapResult with threading.Event
  365. Patch by Charles-Francois Natali
  366. - Pool: Support running without TimeoutHandler thread.
  367. - The with_*_thread arguments has also been replaced with
  368. a single `threads=True` argument.
  369. - Two new pool callbacks:
  370. - ``on_timeout_set(job, soft, hard)``
  371. Applied when a task is executed with a timeout.
  372. - ``on_timeout_cancel(job)``
  373. Applied when a timeout is cancelled (the job completed)
  374. 2.7.3.7 - 2012-05-21
  375. --------------------
  376. - Fixes Python 2.5 support.
  377. 2.7.3.6 - 2012-05-21
  378. --------------------
  379. - Pool: Can now be used in an event loop, without starting the supporting
  380. threads (TimeoutHandler still not supported)
  381. To facilitate this the pool has gained the following keyword arguments:
  382. - ``with_task_thread``
  383. - ``with_result_thread``
  384. - ``with_supervisor_thread``
  385. - ``on_process_up``
  386. Callback called with Process instance as argument
  387. whenever a new worker process is added.
  388. Used to add new process fds to the eventloop::
  389. def on_process_up(proc):
  390. hub.add_reader(proc.sentinel, pool.maintain_pool)
  391. - ``on_process_down``
  392. Callback called with Process instance as argument
  393. whenever a new worker process is found dead.
  394. Used to remove process fds from the eventloop::
  395. def on_process_down(proc):
  396. hub.remove(proc.sentinel)
  397. - ``semaphore``
  398. Sets the semaphore used to protect from adding new items to the
  399. pool when no processes available. The default is a threaded
  400. one, so this can be used to change to an async semaphore.
  401. And the following attributes::
  402. - ``readers``
  403. A map of ``fd`` -> ``callback``, to be registered in an eventloop.
  404. Currently this is only the result outqueue with a callback
  405. that processes all currently incoming results.
  406. And the following methods::
  407. - ``did_start_ok``
  408. To be called after starting the pool, and after setting up the
  409. eventloop with the pool fds, to ensure that the worker processes
  410. didn't immediately exit caused by an error (internal/memory).
  411. - ``maintain_pool``
  412. Public version of ``_maintain_pool`` that handles max restarts.
  413. - Pool: Process too frequent restart protection now only counts if the process
  414. had a non-successful exit-code.
  415. This to take into account the maxtasksperchild option, and allowing
  416. processes to exit cleanly on their own.
  417. - Pool: New options max_restart + max_restart_freq
  418. This means that the supervisor can't restart processes
  419. faster than max_restart' times per max_restart_freq seconds
  420. (like the Erlang supervisor maxR & maxT settings).
  421. The pool is closed and joined if the max restart
  422. frequency is exceeded, where previously it would keep restarting
  423. at an unlimited rate, possibly crashing the system.
  424. The current default value is to stop if it exceeds
  425. 100 * process_count restarts in 1 seconds. This may change later.
  426. It will only count processes with an unsuccessful exit code,
  427. this is to take into account the ``maxtasksperchild`` setting
  428. and code that voluntarily exits.
  429. - Pool: The ``WorkerLostError`` message now includes the exit-code of the
  430. process that disappeared.
  431. 2.7.3.5 - 2012-05-09
  432. --------------------
  433. - Now always cleans up after ``sys.exc_info()`` to avoid
  434. cyclic references.
  435. - ExceptionInfo without arguments now defaults to ``sys.exc_info``.
  436. - Forking can now be disabled using the
  437. ``MULTIPROCESSING_FORKING_DISABLE`` environment variable.
  438. Also this envvar is set so that the behavior is inherited
  439. after execv.
  440. - The semaphore cleanup process started when execv is used
  441. now sets a useful process name if the ``setproctitle``
  442. module is installed.
  443. - Sets the ``FORKED_BY_MULTIPROCESSING``
  444. environment variable if forking is disabled.
  445. 2.7.3.4 - 2012-04-27
  446. --------------------
  447. - Added `billiard.ensure_multiprocessing()`
  448. Raises NotImplementedError if the platform does not support
  449. multiprocessing (e.g. Jython).
  450. 2.7.3.3 - 2012-04-23
  451. --------------------
  452. - PyPy now falls back to using its internal _multiprocessing module,
  453. so everything works except for forking_enable(False) (which
  454. silently degrades).
  455. - Fixed Python 2.5 compat. issues.
  456. - Uses more with statements
  457. - Merged some of the changes from the Python 3 branch.
  458. 2.7.3.2 - 2012-04-20
  459. --------------------
  460. - Now installs on PyPy/Jython (but does not work).
  461. 2.7.3.1 - 2012-04-20
  462. --------------------
  463. - Python 2.5 support added.
  464. 2.7.3.0 - 2012-04-20
  465. --------------------
  466. - Updated from Python 2.7.3
  467. - Python 2.4 support removed, now only supports 2.5, 2.6 and 2.7.
  468. (may consider py3k support at some point).
  469. - Pool improvements from Celery.
  470. - no-execv patch added (http://bugs.python.org/issue8713)
  471. Platform: UNKNOWN
  472. Classifier: Development Status :: 5 - Production/Stable
  473. Classifier: Intended Audience :: Developers
  474. Classifier: Programming Language :: Python
  475. Classifier: Programming Language :: C
  476. Classifier: Programming Language :: Python :: 2
  477. Classifier: Programming Language :: Python :: 2.5
  478. Classifier: Programming Language :: Python :: 2.6
  479. Classifier: Programming Language :: Python :: 2.7
  480. Classifier: Programming Language :: Python :: 3
  481. Classifier: Programming Language :: Python :: 3.2
  482. Classifier: Programming Language :: Python :: 3.3
  483. Classifier: Programming Language :: Python :: Implementation :: CPython
  484. Classifier: Programming Language :: Python :: Implementation :: Jython
  485. Classifier: Programming Language :: Python :: Implementation :: PyPy
  486. Classifier: Operating System :: Microsoft :: Windows
  487. Classifier: Operating System :: POSIX
  488. Classifier: License :: OSI Approved :: BSD License
  489. Classifier: Topic :: Software Development :: Libraries :: Python Modules
  490. Classifier: Topic :: System :: Distributed Computing