T
- The type of the data set filtered by the operator.@Deprecated @Public public class FilterOperator<T> extends SingleInputUdfOperator<T,T,FilterOperator<T>>
Modifier and Type | Field and Description |
---|---|
protected String |
defaultName
Deprecated.
|
protected FilterFunction<T> |
function
Deprecated.
|
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
FilterOperator(DataSet<T> input,
FilterFunction<T> function,
String defaultName)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected FilterFunction<T> |
getFunction()
Deprecated.
|
protected FilterOperatorBase<T,FlatMapFunction<T,T>> |
translateToDataFlow(Operator<T> input)
Deprecated.
Translates this operation to a data flow operator of the common data flow API.
|
extractSemanticAnnotations, getAnalyzedUdfSemanticsFlag, getBroadcastSets, getParameters, getSemanticProperties, returns, returns, returns, setAnalyzedUdfSemanticsFlag, setSemanticProperties, udfWithForwardedFieldsAnnotation, withBroadcastSet, withForwardedFields, withParameters
getInput, getInputType
getMinResources, getName, getParallelism, getPreferredResources, getResultType, name, setParallelism
aggregate, checkSameExecutionContext, clean, coGroup, collect, combineGroup, count, cross, crossWithHuge, crossWithTiny, distinct, distinct, distinct, distinct, fillInType, filter, first, flatMap, fullOuterJoin, fullOuterJoin, getExecutionEnvironment, getType, groupBy, groupBy, groupBy, iterate, iterateDelta, join, join, joinWithHuge, joinWithTiny, leftOuterJoin, leftOuterJoin, map, mapPartition, max, maxBy, min, minBy, output, partitionByHash, partitionByHash, partitionByHash, partitionByRange, partitionByRange, partitionByRange, partitionCustom, partitionCustom, partitionCustom, print, print, printOnTaskManager, printToErr, printToErr, project, rebalance, reduce, reduceGroup, rightOuterJoin, rightOuterJoin, runOperation, sortPartition, sortPartition, sortPartition, sum, union, write, write, writeAsCsv, writeAsCsv, writeAsCsv, writeAsCsv, writeAsFormattedText, writeAsFormattedText, writeAsText, writeAsText
protected final FilterFunction<T> function
protected final String defaultName
public FilterOperator(DataSet<T> input, FilterFunction<T> function, String defaultName)
protected FilterFunction<T> getFunction()
getFunction
in class SingleInputUdfOperator<T,T,FilterOperator<T>>
protected FilterOperatorBase<T,FlatMapFunction<T,T>> translateToDataFlow(Operator<T> input)
SingleInputOperator
translateToDataFlow
in class SingleInputOperator<T,T,FilterOperator<T>>
input
- The data flow operator that produces this operation's input data.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.