videoflow
First steps
Installing Videoflow
Getting started with Videoflow
How to contribute
Tutorials
Writing your own components
Batch versus realtime mode
Node Allocation
Advanced Flowing
Common Flow Development Patterns
Debugging videoflow applications
Computer vision recipes
Object Tracking Sample Application
Api documentation
videoflow.core package
videoflow.engines package
videoflow.producers package
videoflow.processors package
videoflow.consumers package
videoflow.utils package
videoflow
Docs
»
Index
A
|
B
|
C
|
D
|
E
|
F
|
G
|
H
|
I
|
J
|
K
|
L
|
M
|
N
|
O
|
P
|
R
|
S
|
T
|
U
|
V
|
W
A
Accountant (class in videoflow.core.bottlenecks)
add() (videoflow.utils.generic_utils.Progbar method)
add_child() (videoflow.core.node.Node method)
allocate_and_run_tasks() (videoflow.core.engine.ExecutionEngine method)
B
BatchExecutionEngine (class in videoflow.engines.batch)
BatchprocessingQueueMessenger (class in videoflow.engines.batch)
BoundingBoxAnnotator (class in videoflow.processors.vision.annotators)
BoundingBoxTracker (class in videoflow.processors.vision.trackers)
C
change_device() (videoflow.core.node.ProcessorNode method)
(videoflow.core.task.MultiprocessingProcessorTask method)
(videoflow.core.task.ProcessorTask method)
check_for_termination() (videoflow.core.engine.Messenger method)
(videoflow.engines.batch.BatchprocessingQueueMessenger method)
(videoflow.engines.realtime.RealtimeQueueMessenger method)
children (videoflow.core.node.Node attribute)
close() (videoflow.consumers.video.VideofileWriter method)
(videoflow.core.bottlenecks.MetadataConsumer method)
(videoflow.core.node.Node method)
(videoflow.producers.video.ImageFolderReader method)
(videoflow.producers.video.ImageProducer method)
(videoflow.producers.video.VideoFolderReader method)
(videoflow.producers.video.VideostreamReader method)
colors (videoflow.processors.vision.annotators.SegmenterAnnotator attribute)
CommandlineConsumer (class in videoflow.consumers.basic)
computation_node (videoflow.core.task.NodeTask attribute)
consume() (videoflow.consumers.basic.CommandlineConsumer method)
(videoflow.consumers.basic.FileAppenderConsumer method)
(videoflow.consumers.basic.VoidConsumer method)
(videoflow.consumers.basic.WebhookConsumer method)
(videoflow.consumers.video.VideofileWriter method)
(videoflow.core.bottlenecks.MetadataConsumer method)
(videoflow.core.node.ConsumerNode method)
ConsumerNode (class in videoflow.core.node)
ConsumerTask (class in videoflow.core.task)
CountAggregator (class in videoflow.processors.aggregators)
create_process_task() (in module videoflow.engines.task_functions)
create_process_task_gpu() (in module videoflow.engines.task_functions)
CropImageTransformer (class in videoflow.processors.vision.transformers)
D
DelayedInterrupt (class in videoflow.utils.generic_utils)
DelayedKeyboardInterrupt (class in videoflow.utils.generic_utils)
device_type (videoflow.core.node.ProcessorNode attribute)
(videoflow.core.task.MultiprocessingProcessorTask attribute)
(videoflow.core.task.ProcessorTask attribute)
E
ExecutionEngine (class in videoflow.core.engine)
F
FileAppenderConsumer (class in videoflow.consumers.basic)
flatten() (in module videoflow.utils.graph)
Flow (class in videoflow.core.flow)
FunctionProcessorNode (class in videoflow.core.node)
G
get_actual_proctime() (videoflow.core.bottlenecks.Accountant method)
get_bottlenecks() (videoflow.core.bottlenecks.MetadataConsumer method)
get_file() (in module videoflow.utils.downloader)
get_gpus_available_to_process() (in module videoflow.utils.system)
get_number_of_gpus() (in module videoflow.utils.system)
get_proctime() (videoflow.core.bottlenecks.Accountant method)
get_system_gpus() (in module videoflow.utils.system)
GraphEngine (class in videoflow.core.graph)
H
has_cycle() (in module videoflow.utils.graph)
I
id (videoflow.core.node.Node attribute)
(videoflow.core.task.NodeTask attribute)
IdentityProcessor (class in videoflow.processors.basic)
ImageAnnotator (class in videoflow.processors.vision.annotators)
ImageFolderReader (class in videoflow.producers.video)
ImageProducer (class in videoflow.producers.video)
IntProducer (class in videoflow.producers.basic)
is_last (videoflow.core.task.MultiprocessingOutputTask attribute)
(videoflow.core.task.NodeTask attribute)
J
join() (videoflow.core.flow.Flow method)
join_task_processes() (videoflow.core.engine.ExecutionEngine method)
(videoflow.engines.batch.BatchExecutionEngine method)
(videoflow.engines.realtime.RealtimeExecutionEngine method)
JoinerProcessor (class in videoflow.processors.basic)
K
KerasModel (class in videoflow.utils.keras)
L
Leaf (class in videoflow.core.node)
log() (videoflow.core.bottlenecks.MetricsLogger method)
logtype (videoflow.core.bottlenecks.MetricMessage attribute)
logtype_actualproctime (videoflow.core.bottlenecks.Accountant attribute)
logtype_proctime (videoflow.core.bottlenecks.Accountant attribute)
M
MaskImageTransformer (class in videoflow.processors.vision.transformers)
MaxAggregator (class in videoflow.processors.aggregators)
mean (videoflow.core.bottlenecks.Metric attribute)
Messenger (class in videoflow.core.engine)
metadata (videoflow.core.node.ConsumerNode attribute)
MetadataConsumer (class in videoflow.core.bottlenecks)
Metric (class in videoflow.core.bottlenecks)
MetricMessage (class in videoflow.core.bottlenecks)
MetricsLogger (class in videoflow.core.bottlenecks)
MinAggregator (class in videoflow.processors.aggregators)
ModuleNode (class in videoflow.core.node)
MultiplicationAggregator (class in videoflow.processors.aggregators)
MultiprocessingOutputTask (class in videoflow.core.task)
MultiprocessingProcessorTask (class in videoflow.core.task)
MultiprocessingReceiveTask (class in videoflow.core.task)
MultiprocessingTask (class in videoflow.core.task)
N
name (videoflow.core.bottlenecks.Metric attribute)
nb_tasks (videoflow.core.node.ProcessorNode attribute)
next() (videoflow.core.node.ProducerNode method)
(videoflow.producers.basic.IntProducer method)
(videoflow.producers.video.ImageFolderReader method)
(videoflow.producers.video.ImageProducer method)
(videoflow.producers.video.VideoFolderReader method)
(videoflow.producers.video.VideostreamReader method)
Node (class in videoflow.core.node)
nodeid (videoflow.core.bottlenecks.MetricMessage attribute)
nodes (videoflow.core.node.ModuleNode attribute)
NodeTask (class in videoflow.core.task)
O
ObjectDetector (class in videoflow.processors.vision.detectors)
OneTaskProcessorNode (class in videoflow.core.node)
open() (videoflow.consumers.video.VideofileWriter method)
(videoflow.core.bottlenecks.MetadataConsumer method)
(videoflow.core.node.Node method)
(videoflow.producers.video.ImageFolderReader method)
(videoflow.producers.video.ImageProducer method)
(videoflow.producers.video.VideoFolderReader method)
(videoflow.producers.video.VideostreamReader method)
P
parent_id (videoflow.core.task.NodeTask attribute)
parents (videoflow.core.node.Node attribute)
parse_label_map() (in module videoflow.utils.parsers)
passthrough_message() (videoflow.core.engine.Messenger method)
(videoflow.engines.batch.BatchprocessingQueueMessenger method)
(videoflow.engines.realtime.RealtimeQueueMessenger method)
passthrough_termination_message() (videoflow.core.engine.Messenger method)
(videoflow.engines.batch.BatchprocessingQueueMessenger method)
(videoflow.engines.realtime.RealtimeQueueMessenger method)
process() (videoflow.core.node.FunctionProcessorNode method)
(videoflow.core.node.ProcessorNode method)
(videoflow.core.node.TaskModuleNode method)
(videoflow.core.processor.Processor method)
(videoflow.processors.aggregators.CountAggregator method)
(videoflow.processors.aggregators.MaxAggregator method)
(videoflow.processors.aggregators.MinAggregator method)
(videoflow.processors.aggregators.MultiplicationAggregator method)
(videoflow.processors.aggregators.SumAggregator method)
(videoflow.processors.basic.IdentityProcessor method)
(videoflow.processors.basic.JoinerProcessor method)
(videoflow.processors.vision.annotators.ImageAnnotator method)
(videoflow.processors.vision.detectors.ObjectDetector method)
(videoflow.processors.vision.segmentation.Segmenter method)
(videoflow.processors.vision.trackers.BoundingBoxTracker method)
(videoflow.processors.vision.transformers.CropImageTransformer method)
(videoflow.processors.vision.transformers.MaskImageTransformer method)
(videoflow.processors.vision.transformers.ResizeImageTransformer method)
Processor (class in videoflow.core.processor)
ProcessorNode (class in videoflow.core.node)
ProcessorTask (class in videoflow.core.task)
ProducerNode (class in videoflow.core.node)
ProducerTask (class in videoflow.core.task)
Progbar (class in videoflow.utils.generic_utils)
publish_message() (videoflow.core.engine.Messenger method)
(videoflow.engines.batch.BatchprocessingQueueMessenger method)
(videoflow.engines.realtime.RealtimeQueueMessenger method)
publish_termination_message() (videoflow.core.engine.Messenger method)
(videoflow.engines.batch.BatchprocessingQueueMessenger method)
(videoflow.engines.realtime.RealtimeQueueMessenger method)
R
RealtimeExecutionEngine (class in videoflow.engines.realtime)
RealtimeQueueMessenger (class in videoflow.engines.realtime)
receive_message() (videoflow.core.engine.Messenger method)
(videoflow.engines.batch.BatchprocessingQueueMessenger method)
(videoflow.engines.realtime.RealtimeQueueMessenger method)
receive_message_and_metadata() (videoflow.core.engine.Messenger method)
receive_metadata() (videoflow.core.engine.Messenger method)
receive_raw_message() (videoflow.engines.batch.BatchprocessingQueueMessenger method)
recv_array() (in module videoflow.engines.zeromq)
recv_zipped_pickle() (in module videoflow.engines.zeromq)
remove_child() (videoflow.core.node.Node method)
report_bottlenecks() (videoflow.core.bottlenecks.MetadataConsumer method)
resize_add_padding() (in module videoflow.utils.transforms)
ResizeImageTransformer (class in videoflow.processors.vision.transformers)
run() (videoflow.core.flow.Flow method)
(videoflow.core.task.MultiprocessingOutputTask method)
(videoflow.core.task.MultiprocessingProcessorTask method)
(videoflow.core.task.MultiprocessingReceiveTask method)
(videoflow.core.task.NodeTask method)
(videoflow.core.task.Task method)
S
Segmenter (class in videoflow.processors.vision.segmentation)
SegmenterAnnotator (class in videoflow.processors.vision.annotators)
send_array() (in module videoflow.engines.zeromq)
send_zipped_pickle() (in module videoflow.engines.zeromq)
signal_flow_termination() (videoflow.core.engine.ExecutionEngine method)
(videoflow.engines.batch.BatchExecutionEngine method)
(videoflow.engines.realtime.RealtimeExecutionEngine method)
socket_from_task_id() (in module videoflow.engines.zeromq)
stat_mean (videoflow.core.bottlenecks.Accountant attribute)
stat_variance (videoflow.core.bottlenecks.Accountant attribute)
stop() (videoflow.core.flow.Flow method)
SumAggregator (class in videoflow.processors.aggregators)
supported_datasets (videoflow.processors.vision.annotators.BoundingBoxAnnotator attribute)
(videoflow.processors.vision.annotators.SegmenterAnnotator attribute)
T
Task (class in videoflow.core.task)
task_executor_fn() (in module videoflow.engines.task_functions)
task_executor_gpu_fn() (in module videoflow.engines.task_functions)
task_id_from_socket() (in module videoflow.engines.zeromq)
task_id_from_termination_socket() (in module videoflow.engines.zeromq)
TaskModuleNode (class in videoflow.core.node)
termination_socket_from_task_id() (in module videoflow.engines.zeromq)
topological_sort() (in module videoflow.utils.graph)
(videoflow.core.graph.GraphEngine method)
TrackerAnnotator (class in videoflow.processors.vision.annotators)
U
update() (videoflow.utils.generic_utils.Progbar method)
update_actualproctime() (videoflow.core.bottlenecks.Accountant method)
update_proctime() (videoflow.core.bottlenecks.Accountant method)
update_stat() (videoflow.core.bottlenecks.Accountant method)
update_stats() (videoflow.core.bottlenecks.Metric method)
V
validate_file() (in module videoflow.utils.downloader)
value (videoflow.core.bottlenecks.MetricMessage attribute)
variance (videoflow.core.bottlenecks.Metric attribute)
VideoDeviceReader (class in videoflow.producers.video)
VideoFileReader (class in videoflow.producers.video)
VideofileReader (in module videoflow.producers.video)
VideofileWriter (class in videoflow.consumers.video)
videoflow (module)
videoflow.consumers (module)
videoflow.consumers.basic (module)
videoflow.consumers.video (module)
videoflow.core (module)
videoflow.core.bottlenecks (module)
videoflow.core.constants (module)
videoflow.core.engine (module)
videoflow.core.flow (module)
videoflow.core.graph (module)
videoflow.core.node (module)
videoflow.core.processor (module)
videoflow.core.task (module)
videoflow.engines (module)
videoflow.engines.batch (module)
videoflow.engines.realtime (module)
videoflow.engines.task_functions (module)
videoflow.engines.zeromq (module)
videoflow.processors (module)
videoflow.processors.aggregators (module)
videoflow.processors.basic (module)
videoflow.processors.vision (module)
videoflow.processors.vision.annotators (module)
videoflow.processors.vision.counters (module)
videoflow.processors.vision.detectors (module)
videoflow.processors.vision.pose (module)
videoflow.processors.vision.segmentation (module)
videoflow.processors.vision.trackers (module)
videoflow.processors.vision.transformers (module)
videoflow.producers (module)
videoflow.producers.basic (module)
videoflow.producers.video (module)
videoflow.utils (module)
videoflow.utils.downloader (module)
videoflow.utils.generic_utils (module)
videoflow.utils.graph (module)
videoflow.utils.keras (module)
videoflow.utils.parsers (module)
videoflow.utils.system (module)
videoflow.utils.transforms (module)
videoflow.version (module)
VideoFolderReader (class in videoflow.producers.video)
VideostreamReader (class in videoflow.producers.video)
VideoUrlReader (class in videoflow.producers.video)
VoidConsumer (class in videoflow.consumers.basic)
W
WebhookConsumer (class in videoflow.consumers.basic)