Uses of Interface
org.apache.wayang.spark.operators.SparkExecutionOperator
Packages that use SparkExecutionOperator
Package
Description
-
Uses of SparkExecutionOperator in org.apache.wayang.iejoin.operators
Classes in org.apache.wayang.iejoin.operators that implement SparkExecutionOperatorModifier and TypeClassDescriptionclassSparkIEJoinOperator<Type0 extends Comparable<Type0>,Type1 extends Comparable<Type1>, Input extends Copyable<Input>> Spark implementation of theIEJoinOperator.classSparkIESelfJoinOperator<Type0 extends Comparable<Type0>,Type1 extends 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 -
Uses of SparkExecutionOperator in org.apache.wayang.profiler.spark
Fields in org.apache.wayang.profiler.spark declared as SparkExecutionOperatorFields in org.apache.wayang.profiler.spark with type parameters of type SparkExecutionOperatorModifier and TypeFieldDescriptionprotected Supplier<SparkExecutionOperator>SparkOperatorProfiler.operatorGeneratorMethods in org.apache.wayang.profiler.spark with parameters of type SparkExecutionOperatorModifier and TypeMethodDescriptionprotected voidSparkOperatorProfiler.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 SparkExecutionOperatorModifierConstructorDescriptionBinaryOperatorProfiler(Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, Supplier<?> dataQuantumGenerator0, Supplier<?> dataQuantumGenerator1) SinkProfiler(Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, Supplier<?> dataQuantumGenerator) SparkOperatorProfiler(Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, Supplier<?>... dataQuantumGenerators) SparkSourceProfiler(Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, Supplier<?> dataQuantumGenerator) SparkUnaryOperatorProfiler(Supplier<SparkExecutionOperator> operatorGenerator, Configuration configuration, Supplier<?> dataQuantumGenerator) -
Uses of SparkExecutionOperator in org.apache.wayang.spark.compiler
Methods in org.apache.wayang.spark.compiler with parameters of type SparkExecutionOperatorModifier and TypeMethodDescription<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 appropriateFlatMapFunctionfor deploying the givenFlatMapDescriptoron Apache Spark.<I,O> org.apache.spark.api.java.function.FlatMapFunction<Iterator<I>, O> FunctionCompiler.compile(MapPartitionsDescriptor<I, O> descriptor, SparkExecutionOperator operator, OptimizationContext.OperatorContext operatorContext, ChannelInstance[] inputs) Create an appropriateFunctionfor deploying the givenMapPartitionsDescriptoron Apache Spark'sAbstractJavaRDDLike.mapPartitions(FlatMapFunction).<Type> org.apache.spark.api.java.function.Function<Type,Boolean> FunctionCompiler.compile(PredicateDescriptor<Type> predicateDescriptor, SparkExecutionOperator operator, OptimizationContext.OperatorContext operatorContext, ChannelInstance[] inputs) Create an appropriateFunction-based predicate for deploying the givenPredicateDescriptoron 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 appropriateFunctionfor deploying the givenReduceDescriptoron 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 appropriateFunctionfor deploying the givenTransformationDescriptoron Apache Spark. -
Uses of SparkExecutionOperator in org.apache.wayang.spark.execution
Constructors in org.apache.wayang.spark.execution with parameters of type SparkExecutionOperatorModifierConstructorDescriptionSparkExecutionContext(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 SparkExecutionOperatorModifier and TypeClassDescriptionclassSpark implementation of theSparkBernoulliSampleOperator.classSparkBroadcastOperator<Type>Takes care of creating aBroadcastthat can be used later on.classSparkCacheOperator<Type>Converts an uncachedRddChannelinto a cachedRddChannel.classSparkCartesianOperator<InputType0,InputType1> Spark implementation of theCartesianOperator.classSparkCoGroupOperator<In0,In1, Key> Spark implementation of theJoinOperator.classSparkCollectionSource<Type>Provides aCollectionto a Spark job.classSparkCollectOperator<Type>classSparkCountOperator<Type>Spark implementation of theCountOperator.classSparkDistinctOperator<Type>Spark implementation of theDistinctOperator.classSparkDoWhileOperator<InputType,ConvergenceType> Spark implementation of theDoWhileOperator.classSparkFilterOperator<Type>Spark implementation of theFilterOperator.classSparkFlatMapOperator<InputType,OutputType> Spark implementation of theFlatMapOperator.classSpark implementation of theGlobalMaterializedGroupOperator.classSpark implementation of theGlobalReduceOperator.classSparkIntersectOperator<Type>Spark implementation of theJoinOperator.classSparkJoinOperator<InputType0,InputType1, KeyType> Spark implementation of theJoinOperator.classImplementation of theKafkaTopicSinkoperator for the Spark platform.classProvides aCollectionto a Spark job.classSparkLocalCallbackSink<T extends Serializable>Implementation of theLocalCallbackSinkoperator for the Spark platform.classSparkLoopOperator<InputType,ConvergenceType> Spark implementation of theLoopOperator.classSparkMapOperator<InputType,OutputType> Spark implementation of theMapOperator.classSparkMapPartitionsOperator<InputType,OutputType> Spark implementation of theMapPartitionsOperator.classSparkMaterializedGroupByOperator<Type,KeyType> Spark implementation of theMaterializedGroupByOperator.classOperatorfor theSparkPlatformthat creates a sequence file.classOperatorfor theSparkPlatformthat creates a sequence file.classProvides aCollectionto a Spark job.classSpark implementation of theSampleOperator.classSparkReduceByOperator<Type,KeyType> Spark implementation of theReduceByOperator.classSparkRepeatOperator<Type>Spark implementation of theRepeatOperator.classSpark implementation of theSparkShufflePartitionSampleOperator.classSparkSortOperator<Type,Key> Spark implementation of theSortOperator.classImplementation of theTextFileSinkoperator for the Spark platform.classProvides aCollectionto a Spark job.classSparkTsvFileSink<T extends Tuple2<?,?>> Operatorfor theSparkPlatformthat creates a TSV file.classOperatorfor theSparkPlatformthat creates a sequence file.classSparkUnionAllOperator<Type>Spark implementation of theUnionAllOperator.classSparkZipWithIdOperator<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 SparkExecutionOperatorModifier and TypeClassDescriptionclassclassclassclassclassclassclassDeprecated.classSparkPredictOperator<X,Y>