a_sync
- a_sync package
- Subpackages
- a_sync.a_sync package
- Subpackages
- Submodules
- a_sync.a_sync._descriptor module
- a_sync.a_sync._flags module
- a_sync.a_sync._helpers module
- a_sync.a_sync._kwargs module
- a_sync.a_sync._meta module
- a_sync.a_sync.abstract module
- a_sync.a_sync.base module
- a_sync.a_sync.config module
- a_sync.a_sync.decorator module
- a_sync.a_sync.flags module
- a_sync.a_sync.function module
- a_sync.a_sync.method module
- a_sync.a_sync.property module
- a_sync.a_sync.singleton module
- Module contents
- a_sync.async_property package
- a_sync.asyncio package
- a_sync.primitives package
- a_sync.sphinx package
- a_sync.utils package
- a_sync.a_sync package
- Submodules
- a_sync.ENVIRONMENT_VARIABLES module
- a_sync._smart module
SmartFutureSmartFuture.__init__()SmartFuture.__iter__()SmartFuture._make_cancelled_error()SmartFuture._repr_info()SmartFuture._waiter_done_cleanup_callback()SmartFuture.add_done_callback()SmartFuture.cancel()SmartFuture.cancelled()SmartFuture.done()SmartFuture.exception()SmartFuture.get_loop()SmartFuture.remove_done_callback()SmartFuture.result()SmartFuture.set_exception()SmartFuture.set_result()SmartFuture._asyncio_future_blockingSmartFuture._callbacksSmartFuture._cancel_messageSmartFuture._exceptionSmartFuture._keySmartFuture._log_tracebackSmartFuture._loopSmartFuture._queueSmartFuture._resultSmartFuture._source_tracebackSmartFuture._stateSmartFuture._waiters
SmartTaskSmartTask.__init__()SmartTask.__iter__()SmartTask._make_cancelled_error()SmartTask._repr_info()SmartTask._waiter_done_cleanup_callback()SmartTask.add_done_callback()SmartTask.cancel()SmartTask.cancelled()SmartTask.done()SmartTask.exception()SmartTask.get_coro()SmartTask.get_loop()SmartTask.get_name()SmartTask.get_stack()SmartTask.print_stack()SmartTask.remove_done_callback()SmartTask.result()SmartTask.set_exception()SmartTask.set_name()SmartTask.set_result()SmartTask._asyncio_future_blockingSmartTask._callbacksSmartTask._cancel_messageSmartTask._coroSmartTask._exceptionSmartTask._fut_waiterSmartTask._log_destroy_pendingSmartTask._log_tracebackSmartTask._loopSmartTask._must_cancelSmartTask._resultSmartTask._source_tracebackSmartTask._stateSmartTask._waiters
create_future()set_smart_task_factory()shield()smart_task_factory()
- a_sync._typing module
AsyncUnboundMethodCoroBoundMethodIModifierKwargsModifierKwargs.__getitem__()ModifierKwargs.__init__()ModifierKwargs.__iter__()ModifierKwargs.clear()ModifierKwargs.copy()ModifierKwargs.fromkeys()ModifierKwargs.get()ModifierKwargs.items()ModifierKwargs.keys()ModifierKwargs.pop()ModifierKwargs.popitem()ModifierKwargs.setdefault()ModifierKwargs.update()ModifierKwargs.values()ModifierKwargs.cache_typeModifierKwargs.cache_typedModifierKwargs.defaultModifierKwargs.executorModifierKwargs.ram_cache_maxsizeModifierKwargs.ram_cache_ttlModifierKwargs.runs_per_minuteModifierKwargs.semaphore
SyncBoundMethodSyncUnboundMethodAnyBoundMethodAnyFnAnyGetterFunctionAnyIterableAnyIterableOrAwaitableIterableAnyUnboundMethodAsyncDecoratorAsyncDecoratorOrCoroFnAsyncGetterFunctionCacheTypeCoroFnDefaultModeMaybeAwaitableMaybeCoroNumericPSemaphoreSpecSyncFnSyncGetterFunction
- a_sync.aliases module
- a_sync.debugging module
- a_sync.exceptions module
- a_sync.executor module
AsyncProcessPoolExecutorAsyncProcessPoolExecutor.__init__()AsyncProcessPoolExecutor._adjust_process_count()AsyncProcessPoolExecutor._debug_daemon()AsyncProcessPoolExecutor._ensure_debug_daemon()AsyncProcessPoolExecutor._get_loop()AsyncProcessPoolExecutor._launch_processes()AsyncProcessPoolExecutor._spawn_process()AsyncProcessPoolExecutor._start_debug_daemon()AsyncProcessPoolExecutor._start_executor_manager_thread()AsyncProcessPoolExecutor._stop_debug_daemon()AsyncProcessPoolExecutor.map()AsyncProcessPoolExecutor.run()AsyncProcessPoolExecutor.shutdown()AsyncProcessPoolExecutor.submit()AsyncProcessPoolExecutor._brokenAsyncProcessPoolExecutor._call_queueAsyncProcessPoolExecutor._initargsAsyncProcessPoolExecutor._initializerAsyncProcessPoolExecutor._loopAsyncProcessPoolExecutor._max_workersAsyncProcessPoolExecutor._mp_contextAsyncProcessPoolExecutor._pending_work_itemsAsyncProcessPoolExecutor._processesAsyncProcessPoolExecutor._queue_countAsyncProcessPoolExecutor._queue_management_threadAsyncProcessPoolExecutor._queue_management_thread_wakeupAsyncProcessPoolExecutor._result_queueAsyncProcessPoolExecutor._shutdown_lockAsyncProcessPoolExecutor._shutdown_threadAsyncProcessPoolExecutor._work_idsAsyncProcessPoolExecutor._workersAsyncProcessPoolExecutor.debug_logs_enabledAsyncProcessPoolExecutor.loggerAsyncProcessPoolExecutor.sync_modeAsyncProcessPoolExecutor.worker_count_current
AsyncThreadPoolExecutorAsyncThreadPoolExecutor.__init__()AsyncThreadPoolExecutor._adjust_thread_count()AsyncThreadPoolExecutor._debug_daemon()AsyncThreadPoolExecutor._ensure_debug_daemon()AsyncThreadPoolExecutor._get_loop()AsyncThreadPoolExecutor._initializer_failed()AsyncThreadPoolExecutor._start_debug_daemon()AsyncThreadPoolExecutor._stop_debug_daemon()AsyncThreadPoolExecutor.map()AsyncThreadPoolExecutor.run()AsyncThreadPoolExecutor.shutdown()AsyncThreadPoolExecutor.submit()AsyncThreadPoolExecutor._brokenAsyncThreadPoolExecutor._counterAsyncThreadPoolExecutor._idle_semaphoreAsyncThreadPoolExecutor._initargsAsyncThreadPoolExecutor._initializerAsyncThreadPoolExecutor._loopAsyncThreadPoolExecutor._max_workersAsyncThreadPoolExecutor._shutdownAsyncThreadPoolExecutor._shutdown_lockAsyncThreadPoolExecutor._thread_name_prefixAsyncThreadPoolExecutor._threadsAsyncThreadPoolExecutor._work_queueAsyncThreadPoolExecutor._workersAsyncThreadPoolExecutor.debug_logs_enabledAsyncThreadPoolExecutor.loggerAsyncThreadPoolExecutor.sync_modeAsyncThreadPoolExecutor.worker_count_current
PruningThreadPoolExecutorPruningThreadPoolExecutor.__init__()PruningThreadPoolExecutor._adjust_thread_count()PruningThreadPoolExecutor._debug_daemon()PruningThreadPoolExecutor._ensure_debug_daemon()PruningThreadPoolExecutor._get_loop()PruningThreadPoolExecutor._initializer_failed()PruningThreadPoolExecutor._start_debug_daemon()PruningThreadPoolExecutor._stop_debug_daemon()PruningThreadPoolExecutor.map()PruningThreadPoolExecutor.run()PruningThreadPoolExecutor.shutdown()PruningThreadPoolExecutor.submit()PruningThreadPoolExecutor._adjusting_lockPruningThreadPoolExecutor._brokenPruningThreadPoolExecutor._counterPruningThreadPoolExecutor._idle_semaphorePruningThreadPoolExecutor._initargsPruningThreadPoolExecutor._initializerPruningThreadPoolExecutor._loopPruningThreadPoolExecutor._max_workersPruningThreadPoolExecutor._shutdownPruningThreadPoolExecutor._shutdown_lockPruningThreadPoolExecutor._thread_name_prefixPruningThreadPoolExecutor._threadsPruningThreadPoolExecutor._timeoutPruningThreadPoolExecutor._work_queuePruningThreadPoolExecutor._workersPruningThreadPoolExecutor.debug_logs_enabledPruningThreadPoolExecutor.loggerPruningThreadPoolExecutor.sync_modePruningThreadPoolExecutor.worker_count_current
- a_sync.functools module
- a_sync.future module
ASyncFutureASyncFuture.__getitem__()ASyncFuture.__init__()ASyncFuture.__iter__()ASyncFuture.__next__()ASyncFuture._invoke_callbacks()ASyncFuture.add_done_callback()ASyncFuture.cancel()ASyncFuture.cancelled()ASyncFuture.done()ASyncFuture.exception()ASyncFuture.running()ASyncFuture.set_exception()ASyncFuture.set_result()ASyncFuture.set_running_or_notify_cancel()ASyncFuture.result
future()
- a_sync.iter module
- a_sync.task module
TaskMappingTaskMapping.__aiter__()TaskMapping.__getitem__()TaskMapping.__init__()TaskMapping.__iter__()TaskMapping._if_pop_check_destroyed()TaskMapping._if_pop_clear()TaskMapping._raise_if_empty()TaskMapping._raise_if_not_empty()TaskMapping._start_tasks_for_iterables()TaskMapping._tasks_for_iterables()TaskMapping._wait_for_next_key()TaskMapping.clear()TaskMapping.close()TaskMapping.copy()TaskMapping.fromkeys()TaskMapping.get()TaskMapping.items()TaskMapping.keys()TaskMapping.map()TaskMapping.pop()TaskMapping.popitem()TaskMapping.setdefault()TaskMapping.update()TaskMapping.values()TaskMapping.yield_completed()TaskMapping._destroyedTaskMapping._init_loaderTaskMapping._init_loader_nextTaskMapping._nameTaskMapping._nextTaskMapping._queueTaskMapping._wrapped_funcTaskMapping._wrapped_func_kwargsTaskMapping.allTaskMapping.anyTaskMapping.concurrencyTaskMapping.default_factoryTaskMapping.gatherTaskMapping.maxTaskMapping.minTaskMapping.sum
TaskMappingItemsTaskMappingKeysTaskMappingValues
- Module contents
ASyncCachedPropertyDescriptorASyncCachedPropertyDescriptor.__init__()ASyncCachedPropertyDescriptor._all()ASyncCachedPropertyDescriptor._any()ASyncCachedPropertyDescriptor._check_method_name()ASyncCachedPropertyDescriptor._check_method_sync()ASyncCachedPropertyDescriptor._max()ASyncCachedPropertyDescriptor._min()ASyncCachedPropertyDescriptor._sum()ASyncCachedPropertyDescriptor.del_cache_value()ASyncCachedPropertyDescriptor.deleter()ASyncCachedPropertyDescriptor.get()ASyncCachedPropertyDescriptor.get_cache()ASyncCachedPropertyDescriptor.get_cache_value()ASyncCachedPropertyDescriptor.get_instance_state()ASyncCachedPropertyDescriptor.get_loader()ASyncCachedPropertyDescriptor.get_lock()ASyncCachedPropertyDescriptor.has_cache_value()ASyncCachedPropertyDescriptor.map()ASyncCachedPropertyDescriptor.set_cache_value()ASyncCachedPropertyDescriptor.setter()ASyncCachedPropertyDescriptor._load_valueASyncCachedPropertyDescriptor.allASyncCachedPropertyDescriptor.anyASyncCachedPropertyDescriptor.defaultASyncCachedPropertyDescriptor.field_nameASyncCachedPropertyDescriptor.hidden_method_descriptorASyncCachedPropertyDescriptor.hidden_method_nameASyncCachedPropertyDescriptor.maxASyncCachedPropertyDescriptor.minASyncCachedPropertyDescriptor.modifiersASyncCachedPropertyDescriptor.sum
ASyncGenericBaseASyncGenericSingletonASyncIterableASyncIteratorASyncPropertyDescriptorASyncPropertyDescriptor.__init__()ASyncPropertyDescriptor._all()ASyncPropertyDescriptor._any()ASyncPropertyDescriptor._max()ASyncPropertyDescriptor._min()ASyncPropertyDescriptor._sum()ASyncPropertyDescriptor.awaitable_only()ASyncPropertyDescriptor.get()ASyncPropertyDescriptor.get_loader()ASyncPropertyDescriptor.map()ASyncPropertyDescriptor.allASyncPropertyDescriptor.anyASyncPropertyDescriptor.defaultASyncPropertyDescriptor.field_nameASyncPropertyDescriptor.hidden_method_descriptorASyncPropertyDescriptor.hidden_method_nameASyncPropertyDescriptor.maxASyncPropertyDescriptor.minASyncPropertyDescriptor.modifiersASyncPropertyDescriptor.sum
AsyncProcessPoolExecutorAsyncProcessPoolExecutor.__init__()AsyncProcessPoolExecutor._adjust_process_count()AsyncProcessPoolExecutor._debug_daemon()AsyncProcessPoolExecutor._ensure_debug_daemon()AsyncProcessPoolExecutor._get_loop()AsyncProcessPoolExecutor._launch_processes()AsyncProcessPoolExecutor._spawn_process()AsyncProcessPoolExecutor._start_debug_daemon()AsyncProcessPoolExecutor._start_executor_manager_thread()AsyncProcessPoolExecutor._stop_debug_daemon()AsyncProcessPoolExecutor.map()AsyncProcessPoolExecutor.run()AsyncProcessPoolExecutor.shutdown()AsyncProcessPoolExecutor.submit()AsyncProcessPoolExecutor._brokenAsyncProcessPoolExecutor._call_queueAsyncProcessPoolExecutor._initargsAsyncProcessPoolExecutor._initializerAsyncProcessPoolExecutor._loopAsyncProcessPoolExecutor._max_workersAsyncProcessPoolExecutor._mp_contextAsyncProcessPoolExecutor._pending_work_itemsAsyncProcessPoolExecutor._processesAsyncProcessPoolExecutor._queue_countAsyncProcessPoolExecutor._queue_management_threadAsyncProcessPoolExecutor._queue_management_thread_wakeupAsyncProcessPoolExecutor._result_queueAsyncProcessPoolExecutor._shutdown_lockAsyncProcessPoolExecutor._shutdown_threadAsyncProcessPoolExecutor._work_idsAsyncProcessPoolExecutor._workersAsyncProcessPoolExecutor.debug_logs_enabledAsyncProcessPoolExecutor.loggerAsyncProcessPoolExecutor.sync_modeAsyncProcessPoolExecutor.worker_count_current
AsyncThreadPoolExecutorAsyncThreadPoolExecutor.__init__()AsyncThreadPoolExecutor._adjust_thread_count()AsyncThreadPoolExecutor._debug_daemon()AsyncThreadPoolExecutor._ensure_debug_daemon()AsyncThreadPoolExecutor._get_loop()AsyncThreadPoolExecutor._initializer_failed()AsyncThreadPoolExecutor._start_debug_daemon()AsyncThreadPoolExecutor._stop_debug_daemon()AsyncThreadPoolExecutor.map()AsyncThreadPoolExecutor.run()AsyncThreadPoolExecutor.shutdown()AsyncThreadPoolExecutor.submit()AsyncThreadPoolExecutor._brokenAsyncThreadPoolExecutor._counterAsyncThreadPoolExecutor._idle_semaphoreAsyncThreadPoolExecutor._initargsAsyncThreadPoolExecutor._initializerAsyncThreadPoolExecutor._loopAsyncThreadPoolExecutor._max_workersAsyncThreadPoolExecutor._shutdownAsyncThreadPoolExecutor._shutdown_lockAsyncThreadPoolExecutor._thread_name_prefixAsyncThreadPoolExecutor._threadsAsyncThreadPoolExecutor._work_queueAsyncThreadPoolExecutor._workersAsyncThreadPoolExecutor.debug_logs_enabledAsyncThreadPoolExecutor.loggerAsyncThreadPoolExecutor.sync_modeAsyncThreadPoolExecutor.worker_count_current
CounterLockCounterLock.__init__()CounterLock._debug_daemon()CounterLock._ensure_debug_daemon()CounterLock._get_loop()CounterLock._start_debug_daemon()CounterLock._stop_debug_daemon()CounterLock.is_ready()CounterLock.set()CounterLock.wait_for()CounterLock._loopCounterLock._nameCounterLock.debug_logs_enabledCounterLock.loggerCounterLock.value
EventPrioritySemaphorePrioritySemaphore.__call__()PrioritySemaphore.__getitem__()PrioritySemaphore.__init__()PrioritySemaphore._debug_daemon()PrioritySemaphore._ensure_debug_daemon()PrioritySemaphore._get_loop()PrioritySemaphore._start_debug_daemon()PrioritySemaphore._stop_debug_daemon()PrioritySemaphore._wake_up_next()PrioritySemaphore.acquire()PrioritySemaphore.decorate()PrioritySemaphore.locked()PrioritySemaphore.release()PrioritySemaphore._capacityPrioritySemaphore._context_manager_classPrioritySemaphore._context_managersPrioritySemaphore._loopPrioritySemaphore._potential_lost_waitersPrioritySemaphore._top_priorityPrioritySemaphore._top_priority_managerPrioritySemaphore._valuePrioritySemaphore._waitersPrioritySemaphore.debug_logs_enabledPrioritySemaphore.loggerPrioritySemaphore.name
ProcessPoolExecutorProcessingQueueProcessingQueue.__call__()ProcessingQueue.__init__()ProcessingQueue._ensure_workers()ProcessingQueue._format()ProcessingQueue._get()ProcessingQueue._get_loop()ProcessingQueue._init()ProcessingQueue._put()ProcessingQueue._wakeup_next()ProcessingQueue._worker_coro()ProcessingQueue.close()ProcessingQueue.empty()ProcessingQueue.full()ProcessingQueue.get()ProcessingQueue.get_nowait()ProcessingQueue.join()ProcessingQueue.put()ProcessingQueue.put_nowait()ProcessingQueue.qsize()ProcessingQueue.task_done()ProcessingQueue._closedProcessingQueue._finishedProcessingQueue._gettersProcessingQueue._loopProcessingQueue._maxsizeProcessingQueue._nameProcessingQueue._no_futsProcessingQueue._puttersProcessingQueue._queueProcessingQueue._unfinished_tasksProcessingQueue._workersProcessingQueue.funcProcessingQueue.maxsizeProcessingQueue.nameProcessingQueue.num_workers
PruningThreadPoolExecutorPruningThreadPoolExecutor.__init__()PruningThreadPoolExecutor._adjust_thread_count()PruningThreadPoolExecutor._debug_daemon()PruningThreadPoolExecutor._ensure_debug_daemon()PruningThreadPoolExecutor._get_loop()PruningThreadPoolExecutor._initializer_failed()PruningThreadPoolExecutor._start_debug_daemon()PruningThreadPoolExecutor._stop_debug_daemon()PruningThreadPoolExecutor.map()PruningThreadPoolExecutor.run()PruningThreadPoolExecutor.shutdown()PruningThreadPoolExecutor.submit()PruningThreadPoolExecutor._adjusting_lockPruningThreadPoolExecutor._brokenPruningThreadPoolExecutor._counterPruningThreadPoolExecutor._idle_semaphorePruningThreadPoolExecutor._initargsPruningThreadPoolExecutor._initializerPruningThreadPoolExecutor._loopPruningThreadPoolExecutor._max_workersPruningThreadPoolExecutor._shutdownPruningThreadPoolExecutor._shutdown_lockPruningThreadPoolExecutor._thread_name_prefixPruningThreadPoolExecutor._threadsPruningThreadPoolExecutor._timeoutPruningThreadPoolExecutor._work_queuePruningThreadPoolExecutor._workersPruningThreadPoolExecutor.debug_logs_enabledPruningThreadPoolExecutor.loggerPruningThreadPoolExecutor.sync_modePruningThreadPoolExecutor.worker_count_current
QueueQueue.__init__()Queue._format()Queue._get()Queue._get_loop()Queue._init()Queue._put()Queue._wakeup_next()Queue.empty()Queue.full()Queue.get()Queue.get_all()Queue.get_all_nowait()Queue.get_multi()Queue.get_multi_nowait()Queue.get_nowait()Queue.join()Queue.put()Queue.put_nowait()Queue.qsize()Queue.task_done()Queue._finishedQueue._gettersQueue._loopQueue._maxsizeQueue._puttersQueue._queueQueue._unfinished_tasksQueue.maxsize
SemaphoreSemaphore.__call__()Semaphore.__init__()Semaphore._debug_daemon()Semaphore._ensure_debug_daemon()Semaphore._get_loop()Semaphore._start_debug_daemon()Semaphore._stop_debug_daemon()Semaphore._wake_up_next()Semaphore.acquire()Semaphore.decorate()Semaphore.locked()Semaphore.release()Semaphore._loopSemaphore._valueSemaphore._waitersSemaphore.debug_logs_enabledSemaphore.loggerSemaphore.name
SmartProcessingQueueSmartProcessingQueue.__call__()SmartProcessingQueue.__init__()SmartProcessingQueue._ensure_workers()SmartProcessingQueue._format()SmartProcessingQueue._get()SmartProcessingQueue._get_key()SmartProcessingQueue._get_loop()SmartProcessingQueue._init()SmartProcessingQueue._put()SmartProcessingQueue._wakeup_next()SmartProcessingQueue._worker_coro()SmartProcessingQueue.close()SmartProcessingQueue.empty()SmartProcessingQueue.full()SmartProcessingQueue.get()SmartProcessingQueue.get_nowait()SmartProcessingQueue.join()SmartProcessingQueue.put()SmartProcessingQueue.put_nowait()SmartProcessingQueue.qsize()SmartProcessingQueue.task_done()SmartProcessingQueue._closedSmartProcessingQueue._finishedSmartProcessingQueue._futsSmartProcessingQueue._gettersSmartProcessingQueue._loopSmartProcessingQueue._maxsizeSmartProcessingQueue._nameSmartProcessingQueue._no_futsSmartProcessingQueue._puttersSmartProcessingQueue._queueSmartProcessingQueue._unfinished_tasksSmartProcessingQueue._workersSmartProcessingQueue.funcSmartProcessingQueue.maxsizeSmartProcessingQueue.nameSmartProcessingQueue.num_workers
TaskMappingTaskMapping.__aiter__()TaskMapping.__getitem__()TaskMapping.__init__()TaskMapping.__iter__()TaskMapping._if_pop_check_destroyed()TaskMapping._if_pop_clear()TaskMapping._raise_if_empty()TaskMapping._raise_if_not_empty()TaskMapping._start_tasks_for_iterables()TaskMapping._tasks_for_iterables()TaskMapping._wait_for_next_key()TaskMapping.clear()TaskMapping.close()TaskMapping.copy()TaskMapping.fromkeys()TaskMapping.get()TaskMapping.items()TaskMapping.keys()TaskMapping.map()TaskMapping.pop()TaskMapping.popitem()TaskMapping.setdefault()TaskMapping.update()TaskMapping.values()TaskMapping.yield_completed()TaskMapping._destroyedTaskMapping._init_loaderTaskMapping._init_loader_nextTaskMapping._nameTaskMapping._nextTaskMapping._queueTaskMapping._wrapped_funcTaskMapping._wrapped_func_kwargsTaskMapping.allTaskMapping.anyTaskMapping.concurrencyTaskMapping.default_factoryTaskMapping.gatherTaskMapping.maxTaskMapping.minTaskMapping.sum
ThreadPoolExecutorThreadsafeSemaphoreThreadsafeSemaphore.__call__()ThreadsafeSemaphore.__init__()ThreadsafeSemaphore._debug_daemon()ThreadsafeSemaphore._ensure_debug_daemon()ThreadsafeSemaphore._get_loop()ThreadsafeSemaphore._start_debug_daemon()ThreadsafeSemaphore._stop_debug_daemon()ThreadsafeSemaphore._wake_up_next()ThreadsafeSemaphore.acquire()ThreadsafeSemaphore.decorate()ThreadsafeSemaphore.locked()ThreadsafeSemaphore.release()ThreadsafeSemaphore._loopThreadsafeSemaphore._valueThreadsafeSemaphore._waitersThreadsafeSemaphore.debug_logs_enabledThreadsafeSemaphore.loggerThreadsafeSemaphore.nameThreadsafeSemaphore.semaphore
cached_propertyfiltermappropertysorteda_sync()all()any()as_completed()as_yielded()cgather()create_task()gather()igather()
- Subpackages