prefect.server.schemas.filters
Schemas that define Prefect REST API filtering operations.
Each filter schema includes logic for transforming itself into a SQL where
clause.
Classes
Operator
Operators for combining filter criteria.
Methods:
auto
enum.auto()
to avoid requiring a second import to use AutoEnum
PrefectFilterBaseModel
Base model for Prefect filters
Methods:
as_sql_filter
model_validate_list
reset_fields
_reset_fields
set.
Returns:
- A new instance of the model with the reset fields.
PrefectOperatorFilterBaseModel
Base model for Prefect filters that combines criteria with a user-provided operator
Methods:
as_sql_filter
as_sql_filter
FlowFilterId
Filter by Flow.id
.
Methods:
as_sql_filter
FlowFilterDeployment
Filter by flows by deployment
Methods:
as_sql_filter
FlowFilterName
Filter by Flow.name
.
Methods:
as_sql_filter
FlowFilterTags
Filter by Flow.tags
.
Methods:
as_sql_filter
FlowFilter
Filter for flows. Only flows matching all criteria will be returned.
Methods:
as_sql_filter
FlowRunFilterId
Filter by FlowRun.id
.
Methods:
as_sql_filter
FlowRunFilterName
Filter by FlowRun.name
.
Methods:
as_sql_filter
FlowRunFilterTags
Filter by FlowRun.tags
.
Methods:
as_sql_filter
FlowRunFilterDeploymentId
Filter by FlowRun.deployment_id
.
Methods:
as_sql_filter
FlowRunFilterWorkQueueName
Filter by FlowRun.work_queue_name
.
Methods:
as_sql_filter
FlowRunFilterStateType
Filter by FlowRun.state_type
.
Methods:
as_sql_filter
FlowRunFilterStateName
Filter by FlowRun.state_name
.
Methods:
as_sql_filter
FlowRunFilterState
Filter by FlowRun.state_type
and FlowRun.state_name
.
Methods:
as_sql_filter
FlowRunFilterFlowVersion
Filter by FlowRun.flow_version
.
Methods:
as_sql_filter
FlowRunFilterStartTime
Filter by FlowRun.start_time
.
Methods:
as_sql_filter
FlowRunFilterEndTime
Filter by FlowRun.end_time
.
Methods:
as_sql_filter
FlowRunFilterExpectedStartTime
Filter by FlowRun.expected_start_time
.
Methods:
as_sql_filter
FlowRunFilterNextScheduledStartTime
Filter by FlowRun.next_scheduled_start_time
.
Methods:
as_sql_filter
FlowRunFilterParentFlowRunId
Filter for subflows of a given flow run
Methods:
as_sql_filter
FlowRunFilterParentTaskRunId
Filter by FlowRun.parent_task_run_id
.
Methods:
as_sql_filter
FlowRunFilterIdempotencyKey
Filter by FlowRun.idempotency_key.
Methods:
as_sql_filter
FlowRunFilter
Filter flow runs. Only flow runs matching all criteria will be returned
Methods:
as_sql_filter
only_filters_on_id
TaskRunFilterFlowRunId
Filter by TaskRun.flow_run_id
.
Methods:
as_sql_filter
TaskRunFilterId
Filter by TaskRun.id
.
Methods:
as_sql_filter
TaskRunFilterName
Filter by TaskRun.name
.
Methods:
as_sql_filter
TaskRunFilterTags
Filter by TaskRun.tags
.
Methods:
as_sql_filter
TaskRunFilterStateType
Filter by TaskRun.state_type
.
Methods:
as_sql_filter
TaskRunFilterStateName
Filter by TaskRun.state_name
.
Methods:
as_sql_filter
TaskRunFilterState
Filter by TaskRun.type
and TaskRun.name
.
Methods:
as_sql_filter
TaskRunFilterSubFlowRuns
Filter by TaskRun.subflow_run
.
Methods:
as_sql_filter
TaskRunFilterStartTime
Filter by TaskRun.start_time
.
Methods:
as_sql_filter
TaskRunFilterExpectedStartTime
Filter by TaskRun.expected_start_time
.
Methods:
as_sql_filter
TaskRunFilter
Filter task runs. Only task runs matching all criteria will be returned
Methods:
as_sql_filter
DeploymentFilterId
Filter by Deployment.id
.
Methods:
as_sql_filter
DeploymentFilterName
Filter by Deployment.name
.
Methods:
as_sql_filter
DeploymentOrFlowNameFilter
Filter by Deployment.name
or Flow.name
with a single input string for ilike filtering.
Methods:
as_sql_filter
DeploymentFilterPaused
Filter by Deployment.paused
.
Methods:
as_sql_filter
DeploymentFilterWorkQueueName
Filter by Deployment.work_queue_name
.
Methods:
as_sql_filter
DeploymentFilterConcurrencyLimit
DEPRECATED: Prefer Deployment.concurrency_limit_id
over Deployment.concurrency_limit
.
Methods:
as_sql_filter
DeploymentFilterTags
Filter by Deployment.tags
.
Methods:
as_sql_filter
DeploymentFilter
Filter for deployments. Only deployments matching all criteria will be returned.
Methods:
as_sql_filter
DeploymentScheduleFilterActive
Filter by DeploymentSchedule.active
.
Methods:
as_sql_filter
DeploymentScheduleFilter
Filter for deployments. Only deployments matching all criteria will be returned.
Methods:
as_sql_filter
LogFilterName
Filter by Log.name
.
Methods:
as_sql_filter
LogFilterLevel
Filter by Log.level
.
Methods:
as_sql_filter
LogFilterTimestamp
Filter by Log.timestamp
.
Methods:
as_sql_filter
LogFilterFlowRunId
Filter by Log.flow_run_id
.
Methods:
as_sql_filter
LogFilterTaskRunId
Filter by Log.task_run_id
.
Methods:
as_sql_filter
LogFilter
Filter logs. Only logs matching all criteria will be returned
Methods:
as_sql_filter
FilterSet
A collection of filters for common objects
Methods:
model_validate_list
reset_fields
_reset_fields
set.
Returns:
- A new instance of the model with the reset fields.
BlockTypeFilterName
Filter by BlockType.name
Methods:
as_sql_filter
BlockTypeFilterSlug
Filter by BlockType.slug
Methods:
as_sql_filter
BlockTypeFilter
Filter BlockTypes
Methods:
as_sql_filter
BlockSchemaFilterBlockTypeId
Filter by BlockSchema.block_type_id
.
Methods:
as_sql_filter
BlockSchemaFilterId
Filter by BlockSchema.id
Methods:
as_sql_filter
BlockSchemaFilterCapabilities
Filter by BlockSchema.capabilities
Methods:
as_sql_filter
BlockSchemaFilterVersion
Filter by BlockSchema.capabilities
Methods:
as_sql_filter
BlockSchemaFilter
Filter BlockSchemas
Methods:
as_sql_filter
BlockDocumentFilterIsAnonymous
Filter by BlockDocument.is_anonymous
.
Methods:
as_sql_filter
BlockDocumentFilterBlockTypeId
Filter by BlockDocument.block_type_id
.
Methods:
as_sql_filter
BlockDocumentFilterId
Filter by BlockDocument.id
.
Methods:
as_sql_filter
BlockDocumentFilterName
Filter by BlockDocument.name
.
Methods:
as_sql_filter
BlockDocumentFilter
Filter BlockDocuments. Only BlockDocuments matching all criteria will be returned
Methods:
as_sql_filter
WorkQueueFilterId
Filter by WorkQueue.id
.
Methods:
as_sql_filter
WorkQueueFilterName
Filter by WorkQueue.name
.
Methods:
as_sql_filter
WorkQueueFilter
Filter work queues. Only work queues matching all criteria will be
returned
Methods:
as_sql_filter
WorkPoolFilterId
Filter by WorkPool.id
.
Methods:
as_sql_filter
WorkPoolFilterName
Filter by WorkPool.name
.
Methods:
as_sql_filter
WorkPoolFilterType
Filter by WorkPool.type
.
Methods:
as_sql_filter
WorkPoolFilter
Filter work pools. Only work pools matching all criteria will be returned
Methods:
as_sql_filter
WorkerFilterWorkPoolId
Filter by Worker.worker_config_id
.
Methods:
as_sql_filter
WorkerFilterStatus
Filter by Worker.status
.
Methods:
as_sql_filter
WorkerFilterLastHeartbeatTime
Filter by Worker.last_heartbeat_time
.
Methods:
as_sql_filter
WorkerFilter
Filter by Worker.last_heartbeat_time
.
Methods:
as_sql_filter
ArtifactFilterId
Filter by Artifact.id
.
Methods:
as_sql_filter
ArtifactFilterKey
Filter by Artifact.key
.
Methods:
as_sql_filter
ArtifactFilterFlowRunId
Filter by Artifact.flow_run_id
.
Methods:
as_sql_filter
ArtifactFilterTaskRunId
Filter by Artifact.task_run_id
.
Methods:
as_sql_filter
ArtifactFilterType
Filter by Artifact.type
.
Methods:
as_sql_filter
ArtifactFilter
Filter artifacts. Only artifacts matching all criteria will be returned
Methods:
as_sql_filter
ArtifactCollectionFilterLatestId
Filter by ArtifactCollection.latest_id
.
Methods:
as_sql_filter
ArtifactCollectionFilterKey
Filter by ArtifactCollection.key
.
Methods:
as_sql_filter
ArtifactCollectionFilterFlowRunId
Filter by ArtifactCollection.flow_run_id
.
Methods:
as_sql_filter
ArtifactCollectionFilterTaskRunId
Filter by ArtifactCollection.task_run_id
.
Methods:
as_sql_filter
ArtifactCollectionFilterType
Filter by ArtifactCollection.type
.
Methods:
as_sql_filter
ArtifactCollectionFilter
Filter artifact collections. Only artifact collections matching all criteria will be returned
Methods:
as_sql_filter
VariableFilterId
Filter by Variable.id
.
Methods:
as_sql_filter
VariableFilterName
Filter by Variable.name
.
Methods:
as_sql_filter
VariableFilterTags
Filter by Variable.tags
.
Methods: