Uses of Interface
org.apache.wayang.spark.operators.SparkExecutionOperator
-
-
Uses of SparkExecutionOperator in org.apache.wayang.iejoin.operators
Classes in org.apache.wayang.iejoin.operators that implement SparkExecutionOperator Modifier and Type Class Description class
SparkIEJoinOperator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input extends Copyable<Input>>
Spark implementation of theIEJoinOperator
.class
SparkIESelfJoinOperator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input extends Copyable<Input>>
Spark implementation of theIESelfJoinOperator
. -
Uses of SparkExecutionOperator in org.apache.wayang.jdbc.operators
Classes in org.apache.wayang.jdbc.operators that implement SparkExecutionOperator Modifier and Type Class Description class
SqlToRddOperator
-
Uses of SparkExecutionOperator in org.apache.wayang.profiler.spark
Fields in org.apache.wayang.profiler.spark declared as SparkExecutionOperator Modifier and Type Field Description protected SparkExecutionOperator
SparkOperatorProfiler. operator
Fields in org.apache.wayang.profiler.spark with type parameters of type SparkExecutionOperator Modifier and Type Field Description protected java.util.function.Supplier<SparkExecutionOperator>
SparkOperatorProfiler. operatorGenerator
Methods in org.apache.wayang.profiler.spark with parameters of type SparkExecutionOperator Modifier and Type Method Description protected void
SparkOperatorProfiler. evaluate(SparkExecutionOperator operator, ChannelInstance[] inputs, ChannelInstance[] outputs)
Utility method to invokeevaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext)
.Constructor parameters in org.apache.wayang.profiler.spark with type arguments of type SparkExecutionOperator Constructor Description BinaryOperatorProfiler(java.util.function.Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, java.util.function.Supplier<?> dataQuantumGenerator0, java.util.function.Supplier<?> dataQuantumGenerator1)
SinkProfiler(java.util.function.Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, java.util.function.Supplier<?> dataQuantumGenerator)
SparkOperatorProfiler(java.util.function.Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, java.util.function.Supplier<?>... dataQuantumGenerators)
SparkSourceProfiler(java.util.function.Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, java.util.function.Supplier<?> dataQuantumGenerator)
SparkUnaryOperatorProfiler(java.util.function.Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, java.util.function.Supplier<?> dataQuantumGenerator)
-
Uses of SparkExecutionOperator in org.apache.wayang.spark.compiler
Methods in org.apache.wayang.spark.compiler with parameters of type SparkExecutionOperator Modifier and Type Method Description <I,O>
org.apache.spark.api.java.function.FlatMapFunction<I,O>FunctionCompiler. compile(FlatMapDescriptor<I,O> descriptor, SparkExecutionOperator operator, OptimizationContext.OperatorContext operatorContext, ChannelInstance[] inputs)
Create an appropriateFlatMapFunction
for deploying the givenFlatMapDescriptor
on Apache Spark.<I,O>
org.apache.spark.api.java.function.FlatMapFunction<java.util.Iterator<I>,O>FunctionCompiler. compile(MapPartitionsDescriptor<I,O> descriptor, SparkExecutionOperator operator, OptimizationContext.OperatorContext operatorContext, ChannelInstance[] inputs)
Create an appropriateFunction
for deploying the givenMapPartitionsDescriptor
on Apache Spark'sAbstractJavaRDDLike.mapPartitions(FlatMapFunction)
.<Type> org.apache.spark.api.java.function.Function<Type,java.lang.Boolean>
FunctionCompiler. compile(PredicateDescriptor<Type> predicateDescriptor, SparkExecutionOperator operator, OptimizationContext.OperatorContext operatorContext, ChannelInstance[] inputs)
Create an appropriateFunction
-based predicate for deploying the givenPredicateDescriptor
on Apache Spark.<T> org.apache.spark.api.java.function.Function2<T,T,T>
FunctionCompiler. compile(ReduceDescriptor<T> descriptor, SparkExecutionOperator operator, OptimizationContext.OperatorContext operatorContext, ChannelInstance[] inputs)
Create an appropriateFunction
for deploying the givenReduceDescriptor
on Apache Spark.<I,O>
org.apache.spark.api.java.function.Function<I,O>FunctionCompiler. compile(TransformationDescriptor<I,O> descriptor, SparkExecutionOperator operator, OptimizationContext.OperatorContext operatorContext, ChannelInstance[] inputs)
Create an appropriateFunction
for deploying the givenTransformationDescriptor
on Apache Spark. -
Uses of SparkExecutionOperator in org.apache.wayang.spark.execution
Constructors in org.apache.wayang.spark.execution with parameters of type SparkExecutionOperator Constructor Description SparkExecutionContext(SparkExecutionOperator operator, ChannelInstance[] inputs, int iterationNumber)
Creates a new instance. -
Uses of SparkExecutionOperator in org.apache.wayang.spark.operators
Classes in org.apache.wayang.spark.operators that implement SparkExecutionOperator Modifier and Type Class Description class
SparkBernoulliSampleOperator<Type>
Spark implementation of theSparkBernoulliSampleOperator
.class
SparkBroadcastOperator<Type>
Takes care of creating aBroadcast
that can be used later on.class
SparkCacheOperator<Type>
Converts an uncachedRddChannel
into a cachedRddChannel
.class
SparkCartesianOperator<InputType0,InputType1>
Spark implementation of theCartesianOperator
.class
SparkCoGroupOperator<In0,In1,Key>
Spark implementation of theJoinOperator
.class
SparkCollectionSource<Type>
Provides aCollection
to a Spark job.class
SparkCollectOperator<Type>
class
SparkCountOperator<Type>
Spark implementation of theCountOperator
.class
SparkDistinctOperator<Type>
Spark implementation of theDistinctOperator
.class
SparkDoWhileOperator<InputType,ConvergenceType>
Spark implementation of theDoWhileOperator
.class
SparkFilterOperator<Type>
Spark implementation of theFilterOperator
.class
SparkFlatMapOperator<InputType,OutputType>
Spark implementation of theFlatMapOperator
.class
SparkGlobalMaterializedGroupOperator<Type>
Spark implementation of theGlobalMaterializedGroupOperator
.class
SparkGlobalReduceOperator<Type>
Spark implementation of theGlobalReduceOperator
.class
SparkIntersectOperator<Type>
Spark implementation of theJoinOperator
.class
SparkJoinOperator<InputType0,InputType1,KeyType>
Spark implementation of theJoinOperator
.class
SparkKafkaTopicSink<T>
Implementation of theKafkaTopicSink
operator for the Spark platform.class
SparkKafkaTopicSource
Provides aCollection
to a Spark job.class
SparkLocalCallbackSink<T extends java.io.Serializable>
Implementation of theLocalCallbackSink
operator for the Spark platform.class
SparkLoopOperator<InputType,ConvergenceType>
Spark implementation of theLoopOperator
.class
SparkMapOperator<InputType,OutputType>
Spark implementation of theMapOperator
.class
SparkMapPartitionsOperator<InputType,OutputType>
Spark implementation of theMapPartitionsOperator
.class
SparkMaterializedGroupByOperator<Type,KeyType>
Spark implementation of theMaterializedGroupByOperator
.class
SparkObjectFileSink<T>
Operator
for theSparkPlatform
that creates a sequence file.class
SparkObjectFileSource<T>
Operator
for theSparkPlatform
that creates a sequence file.class
SparkRandomPartitionSampleOperator<Type>
Spark implementation of theSampleOperator
.class
SparkReduceByOperator<Type,KeyType>
Spark implementation of theReduceByOperator
.class
SparkRepeatOperator<Type>
Spark implementation of theRepeatOperator
.class
SparkShufflePartitionSampleOperator<Type>
Spark implementation of theSparkShufflePartitionSampleOperator
.class
SparkSortOperator<Type,Key>
Spark implementation of theSortOperator
.class
SparkTextFileSink<T>
Implementation of theTextFileSink
operator for the Spark platform.class
SparkTextFileSource
Provides aCollection
to a Spark job.class
SparkTsvFileSink<T extends Tuple2<?,?>>
Operator
for theSparkPlatform
that creates a TSV file.class
SparkTsvFileSource<T>
Operator
for theSparkPlatform
that creates a sequence file.class
SparkUnionAllOperator<Type>
Spark implementation of theUnionAllOperator
.class
SparkZipWithIdOperator<InputType>
Spark implementation of theMapOperator
. -
Uses of SparkExecutionOperator in org.apache.wayang.spark.operators.ml
Classes in org.apache.wayang.spark.operators.ml that implement SparkExecutionOperator Modifier and Type Class Description class
SparkDecisionTreeClassificationOperator
class
SparkKMeansOperator
class
SparkLinearRegressionOperator
class
SparkModelTransformOperator<X,Y>
Deprecated.class
SparkPredictOperator<X,Y>
-