Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbortException(String) - Constructor for exception org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.AbortException
- AbstractAlternativeCardinalityPusher - Class in org.apache.wayang.core.optimizer.cardinality
-
Abstract
CardinalityPusher
implementation forOperatorAlternative
s and subclasses. - AbstractAlternativeCardinalityPusher(int[], int[]) - Constructor for class org.apache.wayang.core.optimizer.cardinality.AbstractAlternativeCardinalityPusher
- AbstractAlternativeCardinalityPusher(Operator) - Constructor for class org.apache.wayang.core.optimizer.cardinality.AbstractAlternativeCardinalityPusher
- AbstractChannelInstance - Class in org.apache.wayang.core.platform
-
Template for
ChannelInstance
implementations. - AbstractChannelInstance(Executor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.core.platform.AbstractChannelInstance
-
Creates a new instance and registers it with its
Executor
. - AbstractReferenceCountable - Class in org.apache.wayang.core.util
-
Implements a template for
ReferenceCountable
objects. - AbstractReferenceCountable() - Constructor for class org.apache.wayang.core.util.AbstractReferenceCountable
- AbstractTopologicalTraversal<ActivatorType extends AbstractTopologicalTraversal.Activator<ActivationType>,
ActivationType extends AbstractTopologicalTraversal.Activation<ActivatorType>> - Class in org.apache.wayang.core.plan.wayangplan.traversal -
Encapsulates logic to traverse a
WayangPlan
in a topological, bottom-up manner. - AbstractTopologicalTraversal() - Constructor for class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal
- AbstractTopologicalTraversal.AbortException - Exception in org.apache.wayang.core.plan.wayangplan.traversal
-
Declares that the current traversal should be aborted.
- AbstractTopologicalTraversal.Activation<TActivator extends AbstractTopologicalTraversal.Activator<? extends AbstractTopologicalTraversal.Activation<TActivator>>> - Class in org.apache.wayang.core.plan.wayangplan.traversal
-
Describes a reference to an input of an
AbstractTopologicalTraversal.Activator
. - AbstractTopologicalTraversal.Activator<TActivation extends AbstractTopologicalTraversal.Activation<? extends AbstractTopologicalTraversal.Activator<TActivation>>> - Class in org.apache.wayang.core.plan.wayangplan.traversal
-
Wraps a
CardinalityEstimator
, thereby caching its inputCardinalityEstimate
s and keeping track of its dependentCardinalityEstimator
s. - accept(Collection<?>) - Method in class org.apache.wayang.java.channels.CollectionChannel.Instance
- accept(Collection<?>) - Method in class org.apache.wayang.java.channels.StreamChannel.Instance
- accept(Stream<T>) - Method in class org.apache.wayang.java.channels.StreamChannel.Instance
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.wayang.core.mathex.MathExParser.ConstantContext
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.wayang.core.mathex.MathExParser.ParensExpressionContext
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.wayang.core.mathex.MathExParser.UnaryOperationContext
- accept(ParseTreeVisitor<? extends T>) - Method in class org.apache.wayang.core.mathex.MathExParser.VariableContext
- accept(DataSet, FlinkExecutor) - Method in class org.apache.wayang.flink.channels.DataSetChannel.Instance
- accept(JavaRDD<?>, SparkExecutor) - Method in class org.apache.wayang.spark.channels.RddChannel.Instance
- accept(Broadcast) - Method in class org.apache.wayang.spark.channels.BroadcastChannel.Instance
- accept(ExecutionTaskFlowCompiler.Activation) - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activator
- accept(TopDownPlanVisitor<Payload, Return>, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.mapping.OperatorPattern
- accept(TopDownPlanVisitor<Payload, Return>, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.mapping.SubplanPattern
- accept(TopDownPlanVisitor<Payload, Return>, OutputSlot<?>, Payload) - Method in interface org.apache.wayang.core.plan.wayangplan.ActualOperator
- accept(TopDownPlanVisitor<Payload, Return>, OutputSlot<?>, Payload) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
This method is part of the visitor pattern and calls the appropriate visit method on
visitor
. - accept(TopDownPlanVisitor<Payload, Return>, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- accept(TopDownPlanVisitor<Payload, Return>, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- accept(TopDownPlanVisitor<Payload, Return>, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- accept(NdArray<?>) - Method in class org.apache.wayang.tensorflow.channels.TensorChannel.Instance
- accept(TActivation) - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activator
- accept(T, LazyExecutionLineageNode.Aggregator<T>) - Method in class org.apache.wayang.core.platform.lineage.ChannelLineageNode
- accept(T, LazyExecutionLineageNode.Aggregator<T>) - Method in class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
- accept(T, LazyExecutionLineageNode.Aggregator<T>) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
- accuracy - Variable in class org.apache.wayang.ml4all.algorithms.sgd.SGDLoop
- Action - Interface in org.apache.wayang.core.util
-
This interface represents any piece of code that takes no input and produces no output but may fail.
- Actions - Class in org.apache.wayang.core.util
-
Utilities to perform actions.
- Actions() - Constructor for class org.apache.wayang.core.util.Actions
- Activation(ExecutionTaskFlowCompiler.Activator, int) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activation
- Activation(TActivator) - Constructor for class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activation
- Activator(ExecutionTaskFlowCompiler.ActivatorKey) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activator
-
Convenience constructor.
- Activator(ExecutionOperator) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activator
-
Convenience constructor for when we are not inside of a
LoopImplementation.IterationImplementation
. - Activator(ExecutionOperator, LoopImplementation.IterationImplementation) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activator
-
Creates a new instance.
- Activator(Operator) - Constructor for class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activator
- ActualOperator - Interface in org.apache.wayang.core.plan.wayangplan
-
Operator free of ambiguities.
- Adam - Class in org.apache.wayang.basic.model.optimizer
- Adam(float) - Constructor for class org.apache.wayang.basic.model.optimizer.Adam
- Adam(float, float, float, float, String) - Constructor for class org.apache.wayang.basic.model.optimizer.Adam
- Adam(float, String) - Constructor for class org.apache.wayang.basic.model.optimizer.Adam
- add(C, T) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Adds an element to a
Collection
and returns theCollection
. - add(ChannelConversion) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph
-
Register a new
channelConversion
in this instance, which effectively adds an edge. - add(LoadEstimate, LoadEstimate) - Static method in class org.apache.wayang.core.optimizer.costs.LoadEstimate
-
Adds a the and the given instances.
- add(LoadProfileEstimator) - Method in class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
-
Adds an
AtomicExecution
to this instance. - add(PlanImplementation) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
-
Add a
PlanImplementation
to this instance. - add(ExecutionStage) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStageLoop
- add(AtomicExecution) - Method in class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
-
Adds an
AtomicExecution
to this instance. - add(PartialExecution) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- add(PartialExecution) - Method in interface org.apache.wayang.core.platform.ExecutionState
-
Stores a
PartialExecution
. - add(SparseVector) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- add(T) - Method in class org.apache.wayang.core.util.Canonicalizer
- add(T, int) - Method in class org.apache.wayang.core.util.Counter
-
Counts the given
delta
for the givenelement
. - add2(SparseVector) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- addAll(C, C) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Adds elements to a
Collection
and returns theCollection
. - addAll(Iterable<? extends T>) - Method in class org.apache.wayang.core.util.Canonicalizer
- addAll(Collection<? extends T>) - Method in class org.apache.wayang.core.util.Canonicalizer
- addAll(Counter<T>) - Method in class org.apache.wayang.core.util.Counter
- addAllToBlacklist(Collection<Value>) - Method in class org.apache.wayang.core.api.configuration.ExplicitCollectionProvider
- addAllToWhitelist(Collection<Value>) - Method in class org.apache.wayang.core.api.configuration.ExplicitCollectionProvider
- addAlternative(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- addAlternative(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
-
Adds an
OperatorAlternative.Alternative
to this instance. - addAtomicExecutionFromOperatorContext() - Method in class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
-
Adds an
AtomicExecution
for theLoadProfileEstimator
of the describedOptimizationContext.OperatorContext
. - addBroadcastInput(InputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Register an
InputSlot
as broadcast input of this instance. - addBroadcastInput(InputSlot<?>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- addCardinalityMeasurement(ChannelInstance) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- addCardinalityMeasurement(ChannelInstance) - Method in interface org.apache.wayang.core.platform.ExecutionState
-
Registers a measured cardinality.
- addChannelConversion(ChannelConversion) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- addClassTag(Object, WayangJsonObj) - Static method in class org.apache.wayang.core.util.JsonSerializables
- addClassTag(Object, WayangJsonObj, boolean) - Static method in class org.apache.wayang.core.util.JsonSerializables
- addConfiguration(String, Object) - Method in class org.apache.wayang.commons.util.profiledb.model.Subject
-
Adds a configuration.
- addConjunct(Breakpoint) - Method in class org.apache.wayang.core.platform.ConjunctiveBreakpoint
- addConsumer(ExecutionTask, int) - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Set up a consumer
ExecutionTask
for this instance. - addField(Object) - Method in class org.apache.wayang.basic.data.Record
-
Append a field to this instance.
- addField(String, SqlTypeName) - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableBuilder
- addGivenOrTempPath(String, Configuration) - Method in class org.apache.wayang.basic.channels.FileChannel.Instance
- addInitializedPlatform(Platform) - Method in class org.apache.wayang.core.platform.PartialExecution
- addIterationEnumeration(int, PlanImplementation) - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
- addLoopImplementation(LoopSubplan, LoopImplementation) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Adds a new
LoopImplementation
for a givenLoopSubplan
. - addMapping(Mapping) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- addMeasurement(Measurement) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- addOneTimeLoop(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- addOneTimeLoop(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Add
DefaultOptimizationContext
s for theloop
that is executed once within this instance. - addOneTimeLoop(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Add
OptimizationContext
s for theloop
that is executed once within this instance. - addOneTimeOperator(Operator) - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- addOneTimeOperator(Operator) - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
- addOneTimeOperator(Operator) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Add
OptimizationContext.OperatorContext
s for theoperator
that is executed once within this instance. - addOneTimeOperators(OperatorContainer) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- addOperatorMatch(OperatorMatch) - Method in class org.apache.wayang.core.mapping.SubplanMatch
- addPath(String) - Method in class org.apache.wayang.basic.channels.FileChannel.Instance
- addPlaceholders(Signature.Builder, List<Operand<?>>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm2D
- addPredecessor(LazyExecutionLineageNode) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
-
Adds a predecessor.
- addProperty(String, Object) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- addRequiredPlatform(Platform) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- addResource(AutoCloseable) - Method in class org.apache.wayang.tensorflow.execution.TensorflowContextReference
- addResource(AutoCloseable) - Method in class org.apache.wayang.tensorflow.execution.TensorflowExecutor
- addRounds(TimeMeasurement) - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
- addSibling(Channel) - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Acquaints the given instance with this instance and all existing
Channel.siblings
. - addSink(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Deprecated.
- addStartingStage(ExecutionStage) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
- addSuccessor(ExecutionStage) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Mutually register a predecessor/successor relationship among this and the given instance.
- addTable(WayangTable) - Method in class org.apache.wayang.api.sql.calcite.schema.WayangSchemaBuilder
- addTargetPlatform(Platform) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Optional operation. Restrict this instance to be executed/implemented on a certain
Platform
s or allow a further one if there is already a restriction in place. - addTargetPlatform(Platform) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- addTask(ExecutionTask) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- addToBlacklist(Value) - Method in class org.apache.wayang.core.api.configuration.ExplicitCollectionProvider
- addToWhitelist(Value) - Method in class org.apache.wayang.core.api.configuration.ExplicitCollectionProvider
- addUdfJar(String) - Method in class org.apache.wayang.core.api.Job
-
Adds a
path
to a JAR that is required in one or more UDFs. - addUniqueID<Input extends Copyable<Input>> - Class in org.apache.wayang.iejoin.operators.spark_helpers
-
Created by khayyzy on 5/28/16.
- addUniqueID() - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.addUniqueID
- addUniqueID(int, int) - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.addUniqueID
- aggregate(double[], double[]) - Method in class org.apache.wayang.ml4all.algorithms.sgd.ComputeLogisticGradient
- aggregate(Object) - Method in class org.apache.wayang.flink.compiler.criterion.WayangAggregator
- aggregate(ListValue) - Method in class org.apache.wayang.flink.compiler.criterion.WayangAggregator
- aggregate(Tuple2<Integer, Tuple2<Integer, double[]>>, Tuple2<Integer, Tuple2<Integer, double[]>>) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.KMeansCompute
- aggregate(TimeEstimate, TimeEstimate, TimeEstimate) - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter.ResourceTimeEstimateAggregator
- aggregate(Tuple<Collection<ExecutionLineageNode>, Collection<ChannelInstance>>, ChannelLineageNode) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode.CollectingAggregator
- aggregate(Tuple<Collection<ExecutionLineageNode>, Collection<ChannelInstance>>, ExecutionLineageNode) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode.CollectingAggregator
- aggregate(R, R) - Method in class org.apache.wayang.ml4all.abstraction.api.Compute
-
Aggregates the output of the process() method to use in a group by
- aggregate(T, ChannelLineageNode) - Method in interface org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode.Aggregator
-
Visit an
ChannelLineageNode
. - aggregate(T, ExecutionLineageNode) - Method in interface org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode.Aggregator
-
Visit an
ExecutionLineageNode
. - AggregateAddCols - Class in org.apache.wayang.api.sql.calcite.converter.functions
- AggregateAddCols(List<AggregateCall>) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.AggregateAddCols
- AggregateFunction - Class in org.apache.wayang.api.sql.calcite.converter.functions
- AggregateFunction(List<AggregateCall>) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.AggregateFunction
- AggregateGetResult - Class in org.apache.wayang.api.sql.calcite.converter.functions
- AggregateGetResult(List<AggregateCall>, Set<Integer>) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.AggregateGetResult
- AggregateKeyExtractor - Class in org.apache.wayang.api.sql.calcite.converter.functions
- AggregateKeyExtractor(HashSet<Integer>) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.AggregateKeyExtractor
- AggregateOptimizationContext - Class in org.apache.wayang.core.optimizer
-
This
OptimizationContext
implementation aggregates severalOptimizationContext
s and exposes theirOptimizationContext.OperatorContext
in an aggregated manner. - AggregateOptimizationContext(OptimizationContext.LoopContext) - Constructor for class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- aggregateResult(Expression, Expression) - Method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
- AggregateWrapper<R> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers
- AggregateWrapper(Compute) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.AggregateWrapper
- AggregatingCardinalityEstimator - Class in org.apache.wayang.core.optimizer.cardinality
-
CardinalityEstimator
implementation that can have multiple ways of calculating aCardinalityEstimate
. - AggregatingCardinalityEstimator(List<CardinalityEstimator>) - Constructor for class org.apache.wayang.core.optimizer.cardinality.AggregatingCardinalityEstimator
- AggregationDescriptor<InputType,
OutputType> - Class in org.apache.wayang.core.function -
This descriptor pertains to functions that take multiple data units and aggregate them into a single data unit.
- AggregationDescriptor(Class<InputType>, Class<OutputType>) - Constructor for class org.apache.wayang.core.function.AggregationDescriptor
- AggregationDescriptor(Class<InputType>, Class<OutputType>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.AggregationDescriptor
- AggregationDescriptor(DataUnitGroupType<InputType>, BasicDataUnitType<OutputType>) - Constructor for class org.apache.wayang.core.function.AggregationDescriptor
- AggregationDescriptor(DataUnitGroupType<InputType>, BasicDataUnitType<OutputType>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.AggregationDescriptor
- ALL - Static variable in class org.apache.wayang.flink.channels.ChannelConversions
- ALL - Static variable in class org.apache.wayang.genericjdbc.channels.GenericChannelConversions
- ALL - Static variable in class org.apache.wayang.genericjdbc.mapping.Mappings
- ALL - Static variable in class org.apache.wayang.giraph.channels.ChannelConversions
-
All
ChannelConversion
s. - ALL - Static variable in class org.apache.wayang.giraph.mappings.Mappings
- ALL - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- ALL - Static variable in class org.apache.wayang.postgres.channels.ChannelConversions
- ALL - Static variable in class org.apache.wayang.postgres.mapping.Mappings
- ALL - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- ALL - Static variable in class org.apache.wayang.sqlite3.channels.ChannelConversions
- ALL - Static variable in class org.apache.wayang.sqlite3.mapping.Mappings
- ALL - Static variable in class org.apache.wayang.tensorflow.channels.ChannelConversions
- allMatch(Iterator<T>, Predicate<T>, boolean) - Static method in class org.apache.wayang.core.util.Iterators
- AmazonS3Source - Class in org.apache.wayang.basic.operators
-
This source reads a blob file stored in Amazon s3 and outputs the lines as data units.
- AmazonS3Source(String, String, String) - Constructor for class org.apache.wayang.basic.operators.AmazonS3Source
- AmazonS3Source(String, String, String, String) - Constructor for class org.apache.wayang.basic.operators.AmazonS3Source
- AmazonS3Source(AmazonS3Source) - Constructor for class org.apache.wayang.basic.operators.AmazonS3Source
-
Copies an instance (exclusive of broadcasts).
- AmazonS3Source.CardinalityEstimator - Class in org.apache.wayang.basic.operators
-
Custom
CardinalityEstimator
forFlatMapOperator
s. - AmazonS3SourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
AmazonS3Source
toJavaAmazonS3Source
. - AmazonS3SourceMapping() - Constructor for class org.apache.wayang.java.mapping.AmazonS3SourceMapping
- and(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Creates the new instance that merges this and the given one via logical AND.
- andInPlace(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Accumulates the given instance to this one via logical AND.
- andNot(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Creates the new instance that merges this and the given one via logical AND NOT.
- andNotInPlace(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Accumulates the given instance to this one via logical AND NOT.
- ANY - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
- ANY - Enum constant in enum class org.apache.wayang.basic.operators.SampleOperator.Methods
-
Represents an arbitrary sampling method.
- anyMatch(T[], Predicate<T>) - Static method in class org.apache.wayang.core.util.WayangArrays
- append(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Related to file based storage, Receive a Collection of
Experiment
s and persist them at the end of a file - append(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.storage.FileStorage
-
Append
Experiment
s to aFile
. - append(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.storage.JDBCStorage
-
Append
Experiment
s to aFile
. - append(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Related to file based storage, Receive a Collection of
Experiment
s and persist them at the end of a file - append(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Related to file based storage, Receive an array of
Experiment
s and persist them at the end of a file - append(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.storage.FileStorage
-
Append
Experiment
s to aFile
. - append(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.storage.JDBCStorage
-
Append
Experiment
s to aFile
. - append(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Related to file based storage, Receive an array of
Experiment
s and persist them at the end of a file - appendIterationContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
-
Add a new iteration
OptimizationContext
between second-to-last and final iteration. - Application - Interface in org.apache.wayang.spark.monitoring.interfaces
-
This interface represents an application metrics in a Spark cluster.
- ApplicationEnd - Class in org.apache.wayang.spark.monitoring.metrics
-
The
ApplicationEnd
class represents an application that has ended. - ApplicationEnd() - Constructor for class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- ApplicationStart - Class in org.apache.wayang.spark.monitoring.metrics
-
The ApplicationStart class implements the Application and SerializableObject interfaces.
- ApplicationStart() - Constructor for class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- apply(Iterable<Input>) - Method in class org.apache.wayang.api.python.function.WrappedPythonFunction
- apply(Iterable<V>) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.ComputePerPartitionWrapper
- apply(Iterable<V>) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.TransformPerPartitionWrapper
- apply(Long) - Method in class org.apache.wayang.basic.mapping.PageRankMapping.RankInitializer
- apply(Object, Object) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.ReduceWrapper
- apply(String, int, int, int, double, int) - Method in class org.apache.wayang.apps.sgd.SGDImpl
- apply(String, int, int, int, double, int) - Method in class org.apache.wayang.apps.sgd.SGDImprovedImpl
- apply(String, int, int, int, double, int, Experiment) - Method in class org.apache.wayang.apps.sgd.SGDImpl
- apply(String, int, int, int, double, int, Experiment) - Method in class org.apache.wayang.apps.sgd.SGDImprovedImpl
- apply(List<R>) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.AssignWrapper
- apply(Map<String, Object>) - Method in class org.apache.wayang.core.util.JuelUtils.JuelFunction
- apply(Map<String, Object>, boolean) - Method in class org.apache.wayang.core.util.JuelUtils.JuelFunction
- apply(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.AggregateAddCols
- apply(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.AggregateGetResult
- apply(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.AggregateKeyExtractor
- apply(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.JoinKeyExtractor
- apply(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.MultiConditionJoinKeyExtractor
- apply(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.ProjectMapFuncImpl
- apply(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.SortKeyExtractor
- apply(Record, Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.AggregateFunction
- apply(Tuple2<String, Integer>) - Method in class org.apache.wayang.applications.OutputSerializer
- apply(Tuple2<Record, Record>) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.JoinFlattenResult
- apply(Tuple2<Record, Record>) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.MultiConditionJoinFuncImpl
- apply(R, R) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.AggregateWrapper
- apply(V) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.AssignWrapperLocal
- apply(V) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.ComputeWrapper
- apply(V) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LoopCheckWrapper
- apply(V) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LoopConvergenceWrapper
- apply(V) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.TransformWrapper
- apply(V) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.UpdateLocalWrapper
- apply(V) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.UpdateWrapper
- applyTo(ExecutionStage) - Method in class org.apache.wayang.core.profiling.FullInstrumentationStrategy
- applyTo(ExecutionStage) - Method in interface org.apache.wayang.core.profiling.InstrumentationStrategy
-
Mark
Channel
s within thestage
that should be instrumented. - applyTo(ExecutionStage) - Method in class org.apache.wayang.core.profiling.NoInstrumentationStrategy
- applyTo(ExecutionStage) - Method in class org.apache.wayang.core.profiling.OutboundInstrumentationStrategy
- applyTransformations(Collection<PlanTransformation>) - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Apply all available transformations in the
configuration
to this instance. - approves(CardinalityEstimate) - Method in class org.apache.wayang.core.platform.CardinalityBreakpoint
-
Whether the given
CardinalityEstimate
does not require a breakpoint. - ArgMax - Class in org.apache.wayang.basic.model.op
- ArgMax(int) - Constructor for class org.apache.wayang.basic.model.op.ArgMax
- ArgMax(int, String) - Constructor for class org.apache.wayang.basic.model.op.ArgMax
- asCollection(Iterable<T>, Supplier<C>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Provides the given
iterable
asCollection
. - asList(int...) - Static method in class org.apache.wayang.core.util.WayangArrays
-
Converts
int
varargs into aList
. - asList(long...) - Static method in class org.apache.wayang.core.util.WayangArrays
-
Converts
long
varargs into aList
. - asList(Collection<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
- asQueryable(QueryProvider, SchemaPlus, String) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- assertEqualInputs(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.Operators
-
Compares the inputs of two operators and passes quietly if they are identical.
- assertEqualOutputs(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.Operators
-
Compares the outputs of two operators and passes quietly if they are identical.
- asSet(Iterable<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
- asSet(Collection<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
- asSet(T...) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Provides the given
values
asSet
. - assign(double[], ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.sgd.WeightsUpdate
- assign(List<Tuple2<Integer, double[]>>, ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.KMeansUpdate
- assign(List<R>, ML4allModel) - Method in class org.apache.wayang.ml4all.abstraction.api.Update
-
Assigns the new value of the global variable to the
ML4allModel
- assign(R, ML4allModel) - Method in class org.apache.wayang.ml4all.abstraction.api.UpdateLocal
-
Assigns the new value of the global variable to the
ML4allModel
- assignSortOrders() - Method in class org.apache.wayang.iejoin.operators.IEJoinOperator
- assignSortOrders() - Method in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- assignStages(ExecutionTaskFlow, StageAssignmentTraversal.StageSplittingCriterion...) - Static method in class org.apache.wayang.core.optimizer.enumeration.StageAssignmentTraversal
- AssignWrapper<R> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers
- AssignWrapper(Update) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.AssignWrapper
- AssignWrapperLocal<V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers
- AssignWrapperLocal(UpdateLocal) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.AssignWrapperLocal
- at(int) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
-
Convenience method to set the epoch.
- AtomicExecution - Class in org.apache.wayang.core.platform
-
An atomic execution describes the smallest work unit considered by Wayang's cost model.
- AtomicExecution(LoadProfileEstimator) - Constructor for class org.apache.wayang.core.platform.AtomicExecution
-
Creates a new instance with the given
LoadProfileEstimator
. - AtomicExecution.KeyOrLoadSerializer - Class in org.apache.wayang.core.platform
-
This
JsonSerializer
stores the given instances via theirConfiguration
key, if any, or else by theLoadProfile
that they estimate. - AtomicExecutionGroup - Class in org.apache.wayang.core.platform
- AtomicExecutionGroup(EstimationContext, Platform, Configuration, Collection<AtomicExecution>) - Constructor for class org.apache.wayang.core.platform.AtomicExecutionGroup
- AtomicExecutionGroup.Serializer - Class in org.apache.wayang.core.platform
-
JsonSerializer
implementation forAtomicExecutionGroup
s. - Attr - Class in org.apache.wayang.spark.operators.ml
- Attr() - Constructor for class org.apache.wayang.spark.operators.ml.Attr
- available() - Method in class org.apache.wayang.core.util.LimitedInputStream
- AVG_DISC - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- AVG_PRICE - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- AVG_QTY - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- AzureBlobStorageSource - Class in org.apache.wayang.basic.operators
-
This source reads a blob file stored in Azure Blob Storage and outputs the lines as data units.
- AzureBlobStorageSource(String, String, String) - Constructor for class org.apache.wayang.basic.operators.AzureBlobStorageSource
- AzureBlobStorageSource(String, String, String, String) - Constructor for class org.apache.wayang.basic.operators.AzureBlobStorageSource
- AzureBlobStorageSource(AzureBlobStorageSource) - Constructor for class org.apache.wayang.basic.operators.AzureBlobStorageSource
-
Copies an instance (exclusive of broadcasts).
- AzureBlobStorageSource.CardinalityEstimator - Class in org.apache.wayang.basic.operators
-
Custom
CardinalityEstimator
forFlatMapOperator
s. - AzureBlobStorageSourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
AzureBlobStorageSource
toJavaAzureBlobStorageSource
. - AzureBlobStorageSourceMapping() - Constructor for class org.apache.wayang.java.mapping.AzureBlobStorageSourceMapping
B
- baseContext - Static variable in class org.apache.wayang.core.optimizer.costs.LoadProfileEstimators
-
Base
Context
that provides several functions for estimation purposes. - baseContext - Static variable in interface org.apache.wayang.core.util.mathex.Context
- BASIC_MAPPINGS - Static variable in class org.apache.wayang.basic.mapping.Mappings
- BASIC_MAPPINGS - Static variable in class org.apache.wayang.flink.mapping.Mappings
- BASIC_MAPPINGS - Static variable in class org.apache.wayang.java.mapping.Mappings
- BASIC_MAPPINGS - Static variable in class org.apache.wayang.spark.mapping.Mappings
- BasicDataUnitType<T> - Class in org.apache.wayang.core.types
-
A basic data unit type is elementary and not constructed from other data unit types.
- BasicDataUnitType() - Constructor for class org.apache.wayang.core.types.BasicDataUnitType
- BasicDataUnitType(Class<T>) - Constructor for class org.apache.wayang.core.types.BasicDataUnitType
- basicPlugin() - Static method in class org.apache.wayang.flink.Flink
-
Retrieve the
FlinkBasicPlugin
. - basicPlugin() - Static method in class org.apache.wayang.java.Java
-
Retrieve the
JavaBasicPlugin
. - basicPlugin() - Static method in class org.apache.wayang.spark.Spark
-
Retrieve the
SparkBasicPlugin
. - BatchNorm - Class in org.apache.wayang.basic.model.op.nn
- BatchNorm(int, float, float, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm
- BatchNorm(int, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm
- BatchNorm2D - Class in org.apache.wayang.basic.model.op.nn
- BatchNorm2D(int) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm2D(int, float, float) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm2D(int, float, float, String) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm2D(int, float, float, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm2D(int, float, float, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm2D(int, String) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm2D(int, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm2D(int, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm2D
- BatchNorm3D - Class in org.apache.wayang.basic.model.op.nn
- BatchNorm3D(int) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- BatchNorm3D(int, float, float) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- BatchNorm3D(int, float, float, String) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- BatchNorm3D(int, float, float, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- BatchNorm3D(int, float, float, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- BatchNorm3D(int, String) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- BatchNorm3D(int, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- BatchNorm3D(int, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.BatchNorm3D
- battle(T, T) - Method in interface org.apache.wayang.profiler.log.sampling.Battle
-
Let to elements compete.
- Battle<T> - Interface in org.apache.wayang.profiler.log.sampling
-
Implementation of a battle between to elements.
- beginIteration(Operator, int) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- beginIteration(Operator, int) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- beginIteration(Operator, int, Operator, int) - Method in class org.apache.wayang.basic.operators.LoopOperator
- beginIteration(Operator, Operator) - Method in class org.apache.wayang.basic.operators.LoopOperator
- BERNOULLI - Enum constant in enum class org.apache.wayang.basic.operators.SampleOperator.Methods
-
Bernoulli sampling.
- bias - Variable in class org.apache.wayang.basic.model.op.nn.Conv
- BinaryOperation - Class in org.apache.wayang.core.util.mathex.model
-
An operation
Expression
. - BinaryOperation(Expression, char, Expression) - Constructor for class org.apache.wayang.core.util.mathex.model.BinaryOperation
- BinaryOperationContext(MathExParser.ExpressionContext) - Constructor for class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- BinaryOperatorAdapter<Type> - Class in org.apache.wayang.spark.compiler
-
Wraps a
BinaryOperator
as aFunction2
. - BinaryOperatorAdapter(BinaryOperator<Type>) - Constructor for class org.apache.wayang.spark.compiler.BinaryOperatorAdapter
- BinaryOperatorProfiler - Class in org.apache.wayang.profiler.java
- BinaryOperatorProfiler - Class in org.apache.wayang.profiler.spark
-
SparkOperatorProfiler
implementation forSparkExecutionOperator
s with two inputs and one output. - BinaryOperatorProfiler(Supplier<JavaExecutionOperator>, Supplier<?>, Supplier<?>) - Constructor for class org.apache.wayang.profiler.java.BinaryOperatorProfiler
- BinaryOperatorProfiler(Supplier<SparkExecutionOperator>, Configuration, Supplier<?>, Supplier<?>) - Constructor for class org.apache.wayang.profiler.spark.BinaryOperatorProfiler
- BinaryToUnaryOperator<InputType0,
InputType1, OutputType> - Class in org.apache.wayang.core.plan.wayangplan -
This operator has two inputs and a single output.
- BinaryToUnaryOperator(BinaryToUnaryOperator<InputType0, InputType1, OutputType>) - Constructor for class org.apache.wayang.core.plan.wayangplan.BinaryToUnaryOperator
-
Copies the given instance.
- BinaryToUnaryOperator(DataSetType<InputType0>, DataSetType<InputType1>, DataSetType<OutputType>, boolean) - Constructor for class org.apache.wayang.core.plan.wayangplan.BinaryToUnaryOperator
-
Creates a new instance.
- Bitmask - Class in org.apache.wayang.core.util
-
A mutable bit-mask.
- Bitmask() - Constructor for class org.apache.wayang.core.util.Bitmask
-
Creates a new instance.
- Bitmask(int) - Constructor for class org.apache.wayang.core.util.Bitmask
-
Creates a new instance.
- Bitmask(Bitmask) - Constructor for class org.apache.wayang.core.util.Bitmask
-
Creates a new, copied instance.
- Bitmask(Bitmask, int) - Constructor for class org.apache.wayang.core.util.Bitmask
-
Creates a new, copied instance.
- BitSetJoin<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input> - Class in org.apache.wayang.iejoin.operators.java_helpers -
Created by khayyzy on 5/28/16.
- BitSetJoin<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>> - Class in org.apache.wayang.iejoin.operators.spark_helpers -
Created by khayyzy on 5/28/16.
- BitSetJoin(boolean, boolean, boolean, boolean, boolean, boolean, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.java_helpers.BitSetJoin
- BitSetJoin(boolean, boolean, boolean, boolean, boolean, boolean, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.BitSetJoin
- BLOCK_SIZE_PARAMETER_KEY - Static variable in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
-
The config parameter which defines the fixed length of a record.
- BlockBasedOutput(OutputStream, int) - Constructor for class org.apache.wayang.flink.compiler.WayangFileOutputFormat.BlockBasedOutput
- BOOL - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
- breakAfter(ExecutionStage) - Method in class org.apache.wayang.core.platform.FixBreakpoint
- breakBefore(Collection<ExecutionStage>) - Method in class org.apache.wayang.core.platform.FixBreakpoint
- breakBefore(ExecutionStage) - Method in class org.apache.wayang.core.platform.FixBreakpoint
- Breakpoint - Interface in org.apache.wayang.core.platform
-
Describes when to interrupt the execution of an
ExecutionPlan
. - BroadcastChannel - Class in org.apache.wayang.spark.channels
-
Channel
that represents a broadcasted value. - BroadcastChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.spark.channels.BroadcastChannel
- BroadcastChannel.Instance - Class in org.apache.wayang.spark.channels
-
ChannelInstance
implementation forBroadcastChannel
s. - broadcastTo(int, Operator, String) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Connect an output of this operator as a broadcast input of a second operator.
- broadcastTo(String, Operator, String) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Connect an output of this operator as a broadcast input of a second operator.
- bucketExits(S3FileSystem.S3Pair) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- build() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangSchemaBuilder
- build() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableBuilder
- build() - Method in class org.apache.wayang.basic.model.DLModel.Builder
- build(String) - Static method in class org.apache.wayang.api.sql.calcite.schema.WayangSchemaBuilder
- build(String) - Static method in class org.apache.wayang.api.sql.calcite.schema.WayangTableBuilder
- build2ListObject<TypeXPivot extends Comparable<TypeXPivot>,
TypeXRef extends Comparable<TypeXRef>, Input extends Copyable<Input>> - Class in org.apache.wayang.iejoin.operators.spark_helpers -
Created by khayyzy on 5/28/16.
- build2ListObject(boolean, boolean, Function<Input, TypeXPivot>, Function<Input, TypeXRef>) - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.build2ListObject
- Builder() - Constructor for class org.apache.wayang.basic.model.DLModel.Builder
- buildInitialExecutionPlan() - Method in class org.apache.wayang.core.api.Job
- buildInitialExecutionPlan(String, WayangPlan, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Build an execution plan.
- BuildOutgoingEdgeList() - Constructor for class org.apache.wayang.flink.operators.FlinkPageRankOperator.BuildOutgoingEdgeList
- BYTE - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
C
- CACHED_DESCRIPTOR - Static variable in class org.apache.wayang.spark.channels.RddChannel
- CACHED_RDD_TO_COLLECTION - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- CACHED_RDD_TO_HDFS_OBJECT_FILE - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- CACHED_RDD_TO_HDFS_TSV - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- calculate(EstimationContext) - Method in class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
- calculate(EstimationContext) - Method in class org.apache.wayang.core.optimizer.costs.IntervalLoadEstimator
- calculate(EstimationContext) - Method in class org.apache.wayang.core.optimizer.costs.LoadEstimator
-
Calculate the
LoadEstimate
. - calculate(EstimationContext) - Method in class org.apache.wayang.profiler.log.DynamicLoadEstimator
- calculateJointProbability(CardinalityEstimate[], CardinalityEstimate[]) - Method in class org.apache.wayang.core.optimizer.costs.LoadEstimator
-
Utility method to calculate the probability that all cardinality estimates are correct.
- calculateObservationBasedWeight(PartialExecution) - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- calculateRuntimeBasedWeight(PartialExecution) - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- calculateSpread(CardinalityEstimate) - Method in class org.apache.wayang.core.platform.CardinalityBreakpoint
- call(Input) - Method in class org.apache.wayang.iejoin.operators.java_helpers.extractData
- call(InputType) - Method in class org.apache.wayang.spark.compiler.ExtendedFlatMapFunctionAdapter
- call(InputType) - Method in class org.apache.wayang.spark.compiler.ExtendedFunction
- call(InputType) - Method in class org.apache.wayang.spark.compiler.ExtendedMapFunctionAdapter
- call(InputType) - Method in class org.apache.wayang.spark.compiler.FlatMapFunctionAdapter
- call(InputType) - Method in class org.apache.wayang.spark.compiler.MapFunctionAdapter
- call(InputType) - Method in class org.apache.wayang.spark.compiler.PredicateAdapter
- call(Integer, Iterator<Input>) - Method in class org.apache.wayang.iejoin.operators.spark_helpers.addUniqueID
- call(Integer, Iterator<Tuple2<Long, Input>>) - Method in class org.apache.wayang.iejoin.operators.spark_helpers.build2ListObject
- call(ArrayList<Tuple2<Data<Type0, Type1>, Input>>, ArrayList<Tuple2<Data<Type0, Type1>, Input>>) - Method in class org.apache.wayang.iejoin.operators.java_helpers.BitSetJoin
- call(Iterator<InputType>) - Method in class org.apache.wayang.spark.compiler.ExtendedMapPartitionsFunctionAdapter
- call(Iterator<InputType>) - Method in class org.apache.wayang.spark.compiler.MapPartitionsFunctionAdapter
- call(Operand<T>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowConv2D
- call(Operand<T>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowConv3D
- call(Operand<T>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowConvLSTM2D
- call(Operand<T>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowLinear
- call(Operand<T>, Operand<TBool>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm2D
- call(Operand<T>, Operand<TBool>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm3D
- call(Operand<T>, Operand<T>, Operand<T>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowConvLSTM2D.Cell
- call(Tuple2<Long, Input>) - Method in class org.apache.wayang.iejoin.operators.spark_helpers.extractData
- call(Tuple2<List2AttributesObjectSkinny<Type0, Type1>, List2AttributesObjectSkinny<Type0, Type1>>) - Method in class org.apache.wayang.iejoin.operators.spark_helpers.BitSetJoin
- call(Tuple2<Tuple5<Long, Type0, Type0, Type1, Type1>, Tuple5<Long, Type0, Type0, Type1, Type1>>) - Method in class org.apache.wayang.iejoin.operators.spark_helpers.filterUnwantedBlocks
- call(T) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler.KeyExtractor
- call(Type) - Method in class org.apache.wayang.spark.compiler.ExtendedPredicateAdapater
- call(Type, Type) - Method in class org.apache.wayang.spark.compiler.BinaryOperatorAdapter
- call(Type, Type) - Method in class org.apache.wayang.spark.compiler.ExtendedBinaryOperatorAdapter
- call(Type, Type) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler.Reducer
- callback - Variable in class org.apache.wayang.basic.operators.LocalCallbackSink
- callbackDescriptor - Variable in class org.apache.wayang.basic.operators.LocalCallbackSink
- callV1(Operand<T>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowConv2D
- canConvertConvention(Convention) - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- canHandle(String) - Method in interface org.apache.wayang.core.util.fs.FileSystem
- canHandle(String) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- canHandle(String) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- canHandle(String) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- Canonicalizer<T> - Class in org.apache.wayang.core.util
-
This utility maintains canonical sets of objects.
- Canonicalizer() - Constructor for class org.apache.wayang.core.util.Canonicalizer
- Canonicalizer(int) - Constructor for class org.apache.wayang.core.util.Canonicalizer
- Canonicalizer(Iterable<? extends T>) - Constructor for class org.apache.wayang.core.util.Canonicalizer
- Canonicalizer(Collection<? extends T>) - Constructor for class org.apache.wayang.core.util.Canonicalizer
- Canonicalizer(T...) - Constructor for class org.apache.wayang.core.util.Canonicalizer
- canUpdate(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.cardinality.AbstractAlternativeCardinalityPusher
- canUpdate(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
- canUpdate(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.cardinality.SubplanCardinalityPusher
- canWrap(List<InputSlot<?>>, List<OutputSlot<?>>) - Static method in class org.apache.wayang.core.plan.wayangplan.OperatorContainers
- capture(ExecutionPlan, String) - Static method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement
-
Creates a new instance.
- cardinality() - Method in class org.apache.wayang.core.util.Bitmask
-
Retrieves the number of set bits in this instance.
- CardinalityBreakpoint - Class in org.apache.wayang.core.platform
- CardinalityBreakpoint(double, double, double) - Constructor for class org.apache.wayang.core.platform.CardinalityBreakpoint
-
Creates a new instance.
- CardinalityBreakpoint(Configuration) - Constructor for class org.apache.wayang.core.platform.CardinalityBreakpoint
-
Creates a new instance.
- CardinalityEstimate - Class in org.apache.wayang.core.optimizer.cardinality
-
An estimate of cardinality within a
WayangPlan
expressed as aProbabilisticIntervalEstimate
. - CardinalityEstimate() - Constructor for class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
- CardinalityEstimate(long, long, double) - Constructor for class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
- CardinalityEstimate(long, long, double, boolean) - Constructor for class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
- CardinalityEstimationTraversal - Class in org.apache.wayang.core.optimizer.cardinality
-
CardinalityEstimator
that subsumes a DAG of operators, each one providing a localCardinalityEstimator
. - CardinalityEstimator - Interface in org.apache.wayang.core.optimizer.cardinality
-
Computes
CardinalityEstimate
s. - CardinalityEstimator() - Constructor for class org.apache.wayang.basic.operators.AmazonS3Source.CardinalityEstimator
- CardinalityEstimator() - Constructor for class org.apache.wayang.basic.operators.AzureBlobStorageSource.CardinalityEstimator
- CardinalityEstimator() - Constructor for class org.apache.wayang.basic.operators.GoogleCloudStorageSource.CardinalityEstimator
- CardinalityEstimator() - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSource.CardinalityEstimator
- CardinalityEstimator() - Constructor for class org.apache.wayang.basic.operators.ObjectFileSource.CardinalityEstimator
- CardinalityEstimator() - Constructor for class org.apache.wayang.basic.operators.ParquetSource.CardinalityEstimator
- CardinalityEstimator() - Constructor for class org.apache.wayang.basic.operators.TextFileSource.CardinalityEstimator
- CardinalityEstimatorManager - Class in org.apache.wayang.core.optimizer.cardinality
-
Handles the
CardinalityEstimate
s of aWayangPlan
. - CardinalityEstimatorManager(WayangPlan, OptimizationContext, Configuration) - Constructor for class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimatorManager
- CardinalityPusher - Class in org.apache.wayang.core.optimizer.cardinality
- CardinalityPusher(int[], int[]) - Constructor for class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
- CardinalityPusher(Operator) - Constructor for class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
- CardinalityRepository - Class in org.apache.wayang.core.profiling
-
Stores cardinalities that have been collected by the
CrossPlatformExecutor
. - CardinalityRepository(Configuration) - Constructor for class org.apache.wayang.core.profiling.CardinalityRepository
- CartesianMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
CartesianOperator
toFlinkCartesianOperator
. - CartesianMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
CartesianOperator
toJavaCartesianOperator
. - CartesianMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
CartesianOperator
toSparkCartesianOperator
. - CartesianMapping() - Constructor for class org.apache.wayang.flink.mapping.CartesianMapping
- CartesianMapping() - Constructor for class org.apache.wayang.java.mapping.CartesianMapping
- CartesianMapping() - Constructor for class org.apache.wayang.spark.mapping.CartesianMapping
- CartesianOperator<InputType0,
InputType1> - Class in org.apache.wayang.basic.operators -
This operator returns the cartesian product of elements of input datasets.
- CartesianOperator(Class<InputType0>, Class<InputType1>) - Constructor for class org.apache.wayang.basic.operators.CartesianOperator
- CartesianOperator(CartesianOperator<InputType0, InputType1>) - Constructor for class org.apache.wayang.basic.operators.CartesianOperator
-
Copies an instance (exclusive of broadcasts).
- CartesianOperator(DataSetType<InputType0>, DataSetType<InputType1>) - Constructor for class org.apache.wayang.basic.operators.CartesianOperator
- Cast - Class in org.apache.wayang.basic.model.op
- Cast(String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Cast
- Cast(Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Cast
- Cell(Ops, ConvLSTM2D, Class<T>) - Constructor for class org.apache.wayang.tensorflow.model.op.nn.TensorflowConvLSTM2D.Cell
- changeLocation(URI) - Method in class org.apache.wayang.commons.util.profiledb.storage.FileStorage
-
To change target URI during execution
- changeLocation(URI) - Method in class org.apache.wayang.commons.util.profiledb.storage.JDBCStorage
- changeLocation(URI) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Allows to change where future experiments will be persisted and loaded
- Channel - Class in org.apache.wayang.core.plan.executionplan
-
Models the data movement between to
ExecutionTask
s. - Channel(Channel) - Constructor for class org.apache.wayang.core.plan.executionplan.Channel
-
Creates a new, hierarchical instance.
- Channel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.core.plan.executionplan.Channel
-
Creates a new, non-hierarchical instance and registers it with the given
ExecutionTask
. - ChannelConversion - Class in org.apache.wayang.core.optimizer.channels
- ChannelConversion(ChannelDescriptor, ChannelDescriptor) - Constructor for class org.apache.wayang.core.optimizer.channels.ChannelConversion
- ChannelConversionGraph - Class in org.apache.wayang.core.optimizer.channels
-
This graph contains a set of
ChannelConversion
s. - ChannelConversionGraph(Configuration) - Constructor for class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph
-
Creates a new instance.
- ChannelConversionGraph.CostbasedTreeSelectionStrategy - Class in org.apache.wayang.core.optimizer.channels
-
Prefers
ChannelConversionGraph.Tree
s with lower cost. - ChannelConversionGraph.RandomTreeSelectionStrategy - Class in org.apache.wayang.core.optimizer.channels
-
Prefers
ChannelConversionGraph.Tree
s with lower cost. - channelConversionPlugin() - Static method in class org.apache.wayang.java.Java
-
Retrieve the
JavaChannelConversionPlugin
. - channelConversionPlugin() - Static method in class org.apache.wayang.tensorflow.Tensorflow
-
Retrieve the
TensorflowConversionPlugin
. - ChannelConversions - Class in org.apache.wayang.flink.channels
-
ChannelConversion
s used by theFlinkPlatform
. - ChannelConversions - Class in org.apache.wayang.giraph.channels
-
ChannelConversion
s for theGiraphPlatform
. - ChannelConversions - Class in org.apache.wayang.java.channels
-
ChannelConversion
s for theJavaPlatform
. - ChannelConversions - Class in org.apache.wayang.postgres.channels
-
Register for the
ChannelConversion
s supported for this platform. - ChannelConversions - Class in org.apache.wayang.spark.channels
-
ChannelConversion
s used by theJavaPlatform
. - ChannelConversions - Class in org.apache.wayang.sqlite3.channels
-
Register for the
ChannelConversion
s supported for this platform. - ChannelConversions - Class in org.apache.wayang.tensorflow.channels
-
ChannelConversion
s for theTensorflowPlatform
. - ChannelConversions() - Constructor for class org.apache.wayang.flink.channels.ChannelConversions
- ChannelConversions() - Constructor for class org.apache.wayang.giraph.channels.ChannelConversions
- ChannelConversions() - Constructor for class org.apache.wayang.java.channels.ChannelConversions
- ChannelConversions() - Constructor for class org.apache.wayang.postgres.channels.ChannelConversions
- ChannelConversions() - Constructor for class org.apache.wayang.spark.channels.ChannelConversions
- ChannelConversions() - Constructor for class org.apache.wayang.sqlite3.channels.ChannelConversions
- ChannelConversions() - Constructor for class org.apache.wayang.tensorflow.channels.ChannelConversions
- ChannelDescriptor - Class in org.apache.wayang.core.platform
-
Describes a certain
Channel
type including further parameters. - ChannelDescriptor(Class<? extends Channel>, boolean, boolean) - Constructor for class org.apache.wayang.core.platform.ChannelDescriptor
- ChannelInitializer - Interface in org.apache.wayang.core.plan.executionplan
- ChannelInstance - Interface in org.apache.wayang.core.platform
-
Represents the actual, allocated resource represented by
Channel
. - ChannelLineageNode - Class in org.apache.wayang.core.platform.lineage
-
Encapsulates a
ChannelInstance
in the lazy execution lineage. - ChannelLineageNode(ChannelInstance) - Constructor for class org.apache.wayang.core.platform.lineage.ChannelLineageNode
- channelNames - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- ChannelNode(int, String, String) - Constructor for class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.ChannelNode
- checkAllCriteria() - Method in class org.apache.wayang.core.optimizer.SanityChecker
- checkFlatAlternatives() - Method in class org.apache.wayang.core.optimizer.SanityChecker
-
TODO: (Documentation) add SanityChecker.checkFlatAlternatives labels: documentation,todo
- checkProperSubplans() - Method in class org.apache.wayang.core.optimizer.SanityChecker
-
Check whether
Subplan
s are used properly. - checkSanity(SubplanMatch, Operator) - Method in class org.apache.wayang.core.mapping.ReplacementSubplanFactory
- children - Variable in class org.apache.wayang.core.util.ExplainTreeNode
- choose(CardinalityEstimate, CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.cardinality.AbstractAlternativeCardinalityPusher
-
Merge two
CardinalityEstimate
vectors (point-wise). - cleanUp() - Method in class org.apache.wayang.profiler.spark.SparkCollectionSourceProfiler
- cleanUp() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Override this method to implement any clean-up logic.
- cleanUp() - Method in class org.apache.wayang.profiler.spark.SparkTextFileSourceProfiler
- clear() - Method in class org.apache.wayang.core.util.Canonicalizer
- clear() - Method in class org.apache.wayang.core.util.Counter
- clearMarks() - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- clearMarks() - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Calls
OptimizationContext.OperatorContext.clearMarks()
for all nestedOptimizationContext.OperatorContext
s. - clearMarks() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Calls
OptimizationContext.OperatorContext.clearMarks()
for all nestedOptimizationContext.OperatorContext
s. - clearMarks() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Resets the marks for all
InputSlot
s andOutputSlot
s. - clone() - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allModel
- close() - Method in class org.apache.wayang.api.python.executor.PythonProcessCaller
- close() - Method in class org.apache.wayang.core.profiling.ExecutionLog
- close() - Method in class org.apache.wayang.core.util.LimitedInputStream
- close() - Method in class org.apache.wayang.flink.compiler.OutputFormatConsumer
- close() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat.BlockBasedOutput
- close() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- close() - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator.ResultSetIterator
- close() - Method in class org.apache.wayang.profiler.util.RrdAccessor
- close() - Method in class org.apache.wayang.tensorflow.model.TensorflowModel
- CNT - Variable in class org.apache.wayang.basic.model.optimizer.Optimizer
- coGroup(Iterable<InputType0>, Iterable<InputType1>, Collector<OutputType>) - Method in class org.apache.wayang.flink.compiler.FlinkCoGroupFunction
- CoGroupMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
CoGroupOperator
toFlinkCoGroupOperator
. - CoGroupMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
JoinOperator
toJavaJoinOperator
. - CoGroupMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
CoGroupOperator
toSparkCoGroupOperator
. - CoGroupMapping() - Constructor for class org.apache.wayang.flink.mapping.CoGroupMapping
- CoGroupMapping() - Constructor for class org.apache.wayang.java.mapping.CoGroupMapping
- CoGroupMapping() - Constructor for class org.apache.wayang.spark.mapping.CoGroupMapping
- CoGroupOperator<InputType0,
InputType1, Key> - Class in org.apache.wayang.basic.operators -
This operator groups both inputs by some key and then matches groups with the same key.
- CoGroupOperator(CoGroupOperator<InputType0, InputType1, Key>) - Constructor for class org.apache.wayang.basic.operators.CoGroupOperator
-
Copies an instance (exclusive of broadcasts).
- CoGroupOperator(FunctionDescriptor.SerializableFunction<InputType0, Key>, FunctionDescriptor.SerializableFunction<InputType1, Key>, Class<InputType0>, Class<InputType1>, Class<Key>) - Constructor for class org.apache.wayang.basic.operators.CoGroupOperator
- CoGroupOperator(TransformationDescriptor<InputType0, Key>, TransformationDescriptor<InputType1, Key>) - Constructor for class org.apache.wayang.basic.operators.CoGroupOperator
- CoGroupOperator(TransformationDescriptor<InputType0, Key>, TransformationDescriptor<InputType1, Key>, DataSetType<InputType0>, DataSetType<InputType1>) - Constructor for class org.apache.wayang.basic.operators.CoGroupOperator
- collectAllTasks() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow
- collectAllTasks() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
Collects all
ExecutionTask
s of this instance. - collectAndMark() - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
-
Collect and mark all unmarked
ExecutionLineageNode
s in this instance. - collectAndMark(Collection<ExecutionLineageNode>, Collection<ChannelInstance>) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
-
Collect and mark all unmarked
LazyExecutionLineageNode
s in this instance. - collectConnectedSlots(InputSlot<?>) - Static method in class org.apache.wayang.core.optimizer.OptimizationUtils
-
Collects all
Slot
s that are related to the givenInputSlot
either by aSlotMapping
or byOutputSlot
/InputSlot
occupation. - collectConnectedSlots(OutputSlot<?>) - Static method in class org.apache.wayang.core.optimizer.OptimizationUtils
-
Collects all
Slot
s that are related to the givenOutputSlot
either by aSlotMapping
or byOutputSlot
/InputSlot
occupation. - collectConnectedSlots(Slot<?>) - Static method in class org.apache.wayang.core.optimizer.OptimizationUtils
-
Collects all
Slot
s that are related to the givenSlot
either by aSlotMapping
or byOutputSlot
/InputSlot
occupation. - collectContainers(Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.Operators
-
Creates the hierachy of an operators wrt.
- CollectingAggregator() - Constructor for class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode.CollectingAggregator
- collectInputOperators() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- collection - Variable in class org.apache.wayang.basic.operators.CollectionSource
- COLLECTION_TO_BROADCAST - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- COLLECTION_TO_DATASET - Static variable in class org.apache.wayang.flink.channels.ChannelConversions
- COLLECTION_TO_HDFS_OBJECT_FILE - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- COLLECTION_TO_HDFS_TSV - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- COLLECTION_TO_TENSOR - Static variable in class org.apache.wayang.tensorflow.channels.ChannelConversions
- COLLECTION_TO_UNCACHED_RDD - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- CollectionChannel - Class in org.apache.wayang.java.channels
- CollectionChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.java.channels.CollectionChannel
- CollectionChannel.Instance - Class in org.apache.wayang.java.channels
-
JavaChannelInstance
implementation for theCollectionChannel
. - CollectionProvider<Value> - Class in org.apache.wayang.core.api.configuration
-
Provides a
Collection
of objects. - CollectionProvider(Configuration) - Constructor for class org.apache.wayang.core.api.configuration.CollectionProvider
- CollectionProvider(Configuration, CollectionProvider) - Constructor for class org.apache.wayang.core.api.configuration.CollectionProvider
- CollectionSource<T> - Class in org.apache.wayang.basic.operators
-
This source takes as input a Java
Collection
. - CollectionSource(Collection<T>, Class<T>) - Constructor for class org.apache.wayang.basic.operators.CollectionSource
- CollectionSource(Collection<T>, DataSetType<T>) - Constructor for class org.apache.wayang.basic.operators.CollectionSource
- CollectionSource(CollectionSource) - Constructor for class org.apache.wayang.basic.operators.CollectionSource
-
Copies an instance (exclusive of broadcasts).
- CollectionSourceMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
CollectionSource
toFlinkCollectionSource
. - CollectionSourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
CollectionSource
toJavaCollectionSource
. - CollectionSourceMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
CollectionSource
toSparkCollectionSource
. - CollectionSourceMapping - Class in org.apache.wayang.tensorflow.mapping
-
Mapping from
CollectionSource
toTensorflowCollectionSource
. - CollectionSourceMapping() - Constructor for class org.apache.wayang.flink.mapping.CollectionSourceMapping
- CollectionSourceMapping() - Constructor for class org.apache.wayang.java.mapping.CollectionSourceMapping
- CollectionSourceMapping() - Constructor for class org.apache.wayang.spark.mapping.CollectionSourceMapping
- CollectionSourceMapping() - Constructor for class org.apache.wayang.tensorflow.mapping.CollectionSourceMapping
- CollectionSplittableIterator<T> - Class in org.apache.wayang.flink.operators
- CollectionSplittableIterator(List<T>, int) - Constructor for class org.apache.wayang.flink.operators.CollectionSplittableIterator
- collectMappedInputSlots(InputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- collectMappedInputSlots(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- collectMappedInputSlots(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- collectMappedInputSlots(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- collectMappedOutputSlots(OutputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Collect all inner
OutputSlot
s that are mapped to the givenOutputSlot
. - collectMappedOutputSlots(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- collectMappedOutputSlots(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- collectMappedOutputSlots(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- collector - Variable in class org.apache.wayang.basic.operators.LocalCallbackSink
- collectOutputOperators() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
-
Collect
Operator
s within this instance that are connected to an outerOutputSlot
. - collectParents(Operator, boolean) - Static method in class org.apache.wayang.core.plan.wayangplan.Operators
-
Creates the hierachy of an operators wrt.
- collectReachableTopLevelSources() - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Find the source
Operator
s that are reachable from the sinks. - collectRelatedSlots() - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
-
Collects all
OutputSlot
s that are related to this instance viaOperatorContainer
s. - collectStartOperators(OperatorContainer) - Static method in class org.apache.wayang.core.plan.wayangplan.Operators
- collectTopLevelOperatorByName(String) - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Find the
Operator
in this instance by their name. - collectTopLevelOperatorsByName(String) - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Find the
Operator
s in this instance by their name. - Comparator(boolean, boolean) - Constructor for class org.apache.wayang.iejoin.data.Data.Comparator
- compare(Data, Data) - Method in class org.apache.wayang.iejoin.data.Data.Comparator
- compare(Data, Data) - Method in class org.apache.wayang.iejoin.operators.spark_helpers.revDataComparator
- compare(Tuple2<Data<Type0, Type1>, Input>, Tuple2<Data<Type0, Type1>, Input>) - Method in class org.apache.wayang.iejoin.operators.java_helpers.DataComparator
- compare(Tuple2<Data<Type0, Type1>, Input>, Tuple2<Data<Type0, Type1>, Input>) - Method in class org.apache.wayang.iejoin.operators.java_helpers.revDataComparator
- compareRank(Data<Type0, Type1>) - Method in class org.apache.wayang.iejoin.data.Data
- compareTo(Record) - Method in class org.apache.wayang.basic.data.Record
-
Compares the fields of this record to the fields of another record.
- compareTo(Data<Type0, Type1>) - Method in class org.apache.wayang.iejoin.data.Data
- compareTo(Type0) - Method in class org.apache.wayang.iejoin.data.Data
- compile(FlatMapDescriptor<I, O>) - Method in class org.apache.wayang.java.compiler.FunctionCompiler
-
Compile a transformation.
- compile(FlatMapDescriptor<I, O>, SparkExecutionOperator, OptimizationContext.OperatorContext, ChannelInstance[]) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler
-
Create an appropriate
FlatMapFunction
for deploying the givenFlatMapDescriptor
on Apache Spark. - compile(FunctionDescriptor.ExtendedSerializableFunction<I, Iterable<O>>, FlinkExecutionContext) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compile(FunctionDescriptor.SerializableConsumer<T>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compile(FunctionDescriptor.SerializableFunction<I, Iterable<O>>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
-
Compile a transformation.
- compile(FunctionDescriptor.SerializablePredicate<T>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compile(MapPartitionsDescriptor<I, O>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
-
Compile a partition transformation.
- compile(MapPartitionsDescriptor<I, O>) - Method in class org.apache.wayang.java.compiler.FunctionCompiler
-
Compile a partition transformation.
- compile(MapPartitionsDescriptor<I, O>, FlinkExecutionContext) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compile(MapPartitionsDescriptor<I, O>, SparkExecutionOperator, OptimizationContext.OperatorContext, ChannelInstance[]) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler
-
Create an appropriate
Function
for deploying the givenMapPartitionsDescriptor
on Apache Spark'sAbstractJavaRDDLike.mapPartitions(FlatMapFunction)
. - compile(PredicateDescriptor) - Method in class org.apache.wayang.jdbc.compiler.FunctionCompiler
-
Compile a predicate to a SQL
WHERE
clause. - compile(PredicateDescriptor<Collection<T>>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compile(PredicateDescriptor<Type>) - Method in class org.apache.wayang.java.compiler.FunctionCompiler
- compile(PredicateDescriptor<Type>, SparkExecutionOperator, OptimizationContext.OperatorContext, ChannelInstance[]) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler
-
Create an appropriate
Function
-based predicate for deploying the givenPredicateDescriptor
on Apache Spark. - compile(ReduceDescriptor<T>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
-
Compile a reduction.
- compile(ReduceDescriptor<T>, SparkExecutionOperator, OptimizationContext.OperatorContext, ChannelInstance[]) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler
-
Create an appropriate
Function
for deploying the givenReduceDescriptor
on Apache Spark. - compile(ReduceDescriptor<Type>) - Method in class org.apache.wayang.java.compiler.FunctionCompiler
-
Compile a reduction.
- compile(TransformationDescriptor<I, O>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
-
Compile a transformation.
- compile(TransformationDescriptor<I, O>) - Method in class org.apache.wayang.java.compiler.FunctionCompiler
-
Compile a transformation.
- compile(TransformationDescriptor<I, O>, FlinkExecutionContext) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compile(TransformationDescriptor<I, O>, SparkExecutionOperator, OptimizationContext.OperatorContext, ChannelInstance[]) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler
-
Create an appropriate
Function
for deploying the givenTransformationDescriptor
on Apache Spark. - compileCoGroup() - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- CompiledFunction - Class in org.apache.wayang.core.util.mathex.model
-
Expression
implementation that represents a function with a static implementation. - CompiledFunction(String, ToDoubleFunction<double[]>, List<Expression>) - Constructor for class org.apache.wayang.core.util.mathex.model.CompiledFunction
- compileKeySelector(TransformationDescriptor<T, K>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compileOutput(TransformationDescriptor<T, String>) - Method in class org.apache.wayang.flink.compiler.FunctionCompiler
- compiler - Variable in class org.apache.wayang.flink.execution.FlinkExecutor
-
Compiler to create flink UDFs.
- compiler - Variable in class org.apache.wayang.spark.execution.SparkExecutor
-
Compiler to create Spark UDFs.
- compileToKeyExtractor(TransformationDescriptor<T, K>) - Method in class org.apache.wayang.spark.compiler.FunctionCompiler
-
Compile a key extraction.
- complementBlockInfo(BlockInfo) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- compose(SlotMapping) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
-
Functionally compose two instances.
- CompositeExecutionResource - Interface in org.apache.wayang.core.platform
-
ExecutionResource
that itself containsExecutionResource
s. - CompositeOperator - Interface in org.apache.wayang.core.plan.wayangplan
-
A composite operator can be decomposed into smaller operators.
- compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm
- Compute<R,
V> - Class in org.apache.wayang.ml4all.abstraction.api -
Created by zoi on 22/1/15.
- Compute() - Constructor for class org.apache.wayang.ml4all.abstraction.api.Compute
- ComputeLogisticGradient - Class in org.apache.wayang.ml4all.algorithms.sgd
- ComputeLogisticGradient() - Constructor for class org.apache.wayang.ml4all.algorithms.sgd.ComputeLogisticGradient
- ComputePerPartitionWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - ComputePerPartitionWrapper(Compute) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.ComputePerPartitionWrapper
- ComputeWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - ComputeWrapper(Compute) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.ComputeWrapper
- concat(double[], double[]) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- concat(int[], int[]) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- concatenate(OutputSlot<?>, Collection<Channel>, Map<InputSlot<?>, PlanEnumeration>, OptimizationContext, TimeMeasurement) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
-
Concatenates the
baseEnumeration
via itsopenOutputSlot
to thetargetEnumerations
. - cond0 - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- cond0 - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- cond1 - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- cond1 - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- ConfigProperties() - Constructor for class org.apache.wayang.api.sql.calcite.optimizer.Optimizer.ConfigProperties
- configuration - Variable in class org.apache.wayang.core.api.configuration.CollectionProvider
- configuration - Variable in class org.apache.wayang.core.api.configuration.KeyValueProvider
- Configuration - Class in org.apache.wayang.core.api
-
Describes both the configuration of a
WayangContext
andJob
s. - Configuration() - Constructor for class org.apache.wayang.core.api.Configuration
-
Creates a new top-level instance that bases directly from the default instance.
- Configuration(String) - Constructor for class org.apache.wayang.core.api.Configuration
-
Creates a new top-level instance that bases directly from the default instance and loads the specified configuration file.
- configure(Configuration) - Method in class org.apache.wayang.flink.compiler.OutputFormatConsumer
- configure(Configuration) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- configure(Configuration) - Method in class org.apache.wayang.core.optimizer.enumeration.LatentOperatorPruningStrategy
- configure(Configuration) - Method in interface org.apache.wayang.core.optimizer.enumeration.PlanEnumerationPruningStrategy
-
Configure this instance.
- configure(Configuration) - Method in class org.apache.wayang.core.optimizer.enumeration.RandomPruningStrategy
- configure(Configuration) - Method in class org.apache.wayang.core.optimizer.enumeration.SinglePlatformPruningStrategy
- configure(Configuration) - Method in class org.apache.wayang.core.optimizer.enumeration.TopKPruningStrategy
- configure(Configuration) - Method in interface org.apache.wayang.core.plugin.Plugin
-
Configures the
Configuration
, thereby registering the components of this instance. - configureDefaults(Configuration) - Method in class org.apache.wayang.core.platform.Platform
-
Configure default settings for this instance, e.g., to be able to create
LoadProfileToTimeConverter
s. - configureDefaults(Configuration) - Method in class org.apache.wayang.flink.platform.FlinkPlatform
- configureDefaults(Configuration) - Method in class org.apache.wayang.giraph.platform.GiraphPlatform
- configureDefaults(Configuration) - Method in class org.apache.wayang.java.platform.JavaPlatform
- configureDefaults(Configuration) - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- configureDefaults(Configuration) - Method in class org.apache.wayang.spark.platform.SparkPlatform
- configureDefaults(Configuration) - Method in class org.apache.wayang.tensorflow.platform.TensorflowPlatform
- ConjunctiveBreakpoint - Class in org.apache.wayang.core.platform
-
Breakpoint
implementation that disrupts execution if all aggregatedBreakpoint
s request a disruption. - ConjunctiveBreakpoint(Breakpoint...) - Constructor for class org.apache.wayang.core.platform.ConjunctiveBreakpoint
- connectAll(ChannelInstance[], ExecutionLineageNode, ChannelInstance[]) - Static method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
-
Set all of the
inputs
as predecessors of theoperatorContext
each of theoutputs
. - connectFinalOutputTo(Operator, int) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- connectTo(int, Operator, int) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Connect an output of this operator to the input of a second operator.
- connectTo(String, Operator, String) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Connect an output of this operator to the input of a second operator.
- connectTo(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
-
Connect this output slot to an input slot.
- consideringEnteredOperatorsIf(Predicate<CompositeOperator>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Criterion when to consider an entered
CompositeOperator
as normalOperator
as well. - Constant - Class in org.apache.wayang.core.util.mathex.model
-
A constant
Expression
. - Constant(double) - Constructor for class org.apache.wayang.core.util.mathex.model.Constant
- ConstantContext(MathExParser.ExpressionContext) - Constructor for class org.apache.wayang.core.mathex.MathExParser.ConstantContext
- ConstantLoadProfileEstimator - Class in org.apache.wayang.core.optimizer.costs
-
LoadProfileEstimator
that estimates a predefinedLoadProfile
. - ConstantLoadProfileEstimator(LoadProfile) - Constructor for class org.apache.wayang.core.optimizer.costs.ConstantLoadProfileEstimator
- ConstantValueProvider<Value> - Class in org.apache.wayang.core.api.configuration
-
Used by
Configuration
s to provide some value. - ConstantValueProvider(Configuration) - Constructor for class org.apache.wayang.core.api.configuration.ConstantValueProvider
- ConstantValueProvider(ValueProvider<Value>) - Constructor for class org.apache.wayang.core.api.configuration.ConstantValueProvider
- ConstantValueProvider(Configuration, ValueProvider<Value>) - Constructor for class org.apache.wayang.core.api.configuration.ConstantValueProvider
- ConstantValueProvider(Value, Configuration) - Constructor for class org.apache.wayang.core.api.configuration.ConstantValueProvider
- ConsumerDescriptor<T> - Class in org.apache.wayang.core.function
-
Created by bertty on 13-07-17.
- ConsumerDescriptor(FunctionDescriptor.SerializableConsumer<T>, Class<T>) - Constructor for class org.apache.wayang.core.function.ConsumerDescriptor
- ConsumerDescriptor(FunctionDescriptor.SerializableConsumer<T>, Class<T>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.ConsumerDescriptor
- ConsumerDescriptor(FunctionDescriptor.SerializableConsumer<T>, Class<T>, ProbabilisticDoubleInterval) - Constructor for class org.apache.wayang.core.function.ConsumerDescriptor
- ConsumerDescriptor(FunctionDescriptor.SerializableConsumer<T>, Class<T>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.ConsumerDescriptor
- ConsumerDescriptor(FunctionDescriptor.SerializableConsumer<T>, BasicDataUnitType<T>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.ConsumerDescriptor
- ConsumerIteratorAdapter<T> - Class in org.apache.wayang.core.util
-
Utility to expose interfaces that accept a callback as an
Iterator
. - ConsumerIteratorAdapter() - Constructor for class org.apache.wayang.core.util.ConsumerIteratorAdapter
-
Creates a new instance of capacity 65536.
- ConsumerIteratorAdapter(int) - Constructor for class org.apache.wayang.core.util.ConsumerIteratorAdapter
-
Creates a new instance.
- contains(Object) - Method in class org.apache.wayang.core.util.Canonicalizer
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkCartesianOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkCollectionSink
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkCollectionSource
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkCountOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkDistinctOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- containsAction() - Method in interface org.apache.wayang.flink.operators.FlinkExecutionOperator
-
Tell whether this instances is a Flink action.
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkFilterOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkGroupByOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkIntersectOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkJoinOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkLoopOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkMapOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSink
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSource
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkReduceByOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkRepeatOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkSampleOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkSortOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkTextFileSink
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkTextFileSource
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkTsvFileSink
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkUnionAllOperator
- containsAction() - Method in class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
- containsAction() - Method in class org.apache.wayang.iejoin.operators.SparkIEJoinOperator
- containsAction() - Method in class org.apache.wayang.iejoin.operators.SparkIESelfJoinOperator
- containsAction() - Method in class org.apache.wayang.jdbc.operators.SqlToRddOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkModelTransformOperator
-
Deprecated.
- containsAction() - Method in class org.apache.wayang.spark.operators.ml.SparkPredictOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkBroadcastOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkCacheOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkCartesianOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkCoGroupOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkCollectionSource
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkCollectOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkCountOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkDistinctOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkDoWhileOperator
- containsAction() - Method in interface org.apache.wayang.spark.operators.SparkExecutionOperator
-
Tell whether this instances is a Spark action.
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkFilterOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkFlatMapOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkIntersectOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkJoinOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkLocalCallbackSink
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkLoopOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkMapOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkObjectFileSink
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkObjectFileSource
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkParquetSource
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkReduceByOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkRepeatOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkSortOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkTextFileSink
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkTextFileSource
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkTsvFileSink
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkTsvFileSource
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkUnionAllOperator
- containsAction() - Method in class org.apache.wayang.spark.operators.SparkZipWithIdOperator
- containsAll(Collection<?>) - Method in class org.apache.wayang.core.util.Canonicalizer
- Context - Interface in org.apache.wayang.core.util.mathex
-
Provides contextual variables and functions in order to evaluate an
Expression
. - Conv - Class in org.apache.wayang.basic.model.op.nn
- Conv(int, int, int[], int[], String, boolean, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv
- Conv2D - Class in org.apache.wayang.basic.model.op.nn
- Conv2D(int, int, int[], int[], String, boolean) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv2D
- Conv2D(int, int, int[], int[], String, boolean, String) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv2D
- Conv2D(int, int, int[], int[], String, boolean, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv2D
- Conv2D(int, int, int[], int[], String, boolean, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv2D
- Conv3D - Class in org.apache.wayang.basic.model.op.nn
- Conv3D(int, int, int[], int[], String, boolean) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv3D
- Conv3D(int, int, int[], int[], String, boolean, String) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv3D
- Conv3D(int, int, int[], int[], String, boolean, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv3D
- Conv3D(int, int, int[], int[], String, boolean, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.Conv3D
- CONVERGENCE_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.DoWhileOperator
- conversionPlugin() - Static method in class org.apache.wayang.flink.Flink
-
Retrieve the
FlinkConversionPlugin
. - conversionPlugin() - Static method in class org.apache.wayang.genericjdbc.GenericJdbc
-
Retrieve the
GenericJdbcConversionsPlugin
. - conversionPlugin() - Static method in class org.apache.wayang.postgres.Postgres
-
Retrieve the
PostgresConversionsPlugin
. - conversionPlugin() - Static method in class org.apache.wayang.spark.Spark
-
Retrieve the
SparkConversionPlugin
. - conversionPlugin() - Static method in class org.apache.wayang.sqlite3.Sqlite3
-
Retrieve the
Sqlite3ConversionPlugin
. - convert(TypeReference<T>) - Static method in class org.apache.wayang.core.util.TypeConverter
- convert(RelNode) - Method in class org.apache.wayang.api.sql.calcite.converter.WayangRelConverter
- convert(RelNode) - Method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- convert(RelNode) - Method in class org.apache.wayang.api.sql.calcite.rules.WayangSortRule
- convert(RelNode, Collection<Record>) - Method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- convert(RelDataType, String) - Static method in class org.apache.wayang.api.sql.sources.fs.CsvRowConverter
- convert(SqlNode) - Method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- convert(LoadEstimate) - Method in class org.apache.wayang.core.optimizer.costs.LoadToTimeConverter
- convert(LoadProfile) - Method in class org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter
-
Estimate the time required to execute something with the given
loadProfile
. - convert(TimeEstimate) - Method in class org.apache.wayang.core.optimizer.costs.TimeToCostConverter
-
Convert the given
TimeEstimate
into a cost estimate. - convert(Channel, Configuration) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
-
Converts the given
sourceChannel
into a newChannel
according toChannelConversion.targetChannelDescriptor
. - convert(Channel, Configuration, Collection<OptimizationContext>, CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
-
Converts the given
sourceChannel
into a newChannel
according toChannelConversion.targetChannelDescriptor
. - convert(Channel, Configuration, Collection<OptimizationContext>, CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- convert(Graph, Optimizer) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Graph, Ops, BatchNorm2D, Operand<?>, Operand<TBool>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Graph, Ops, BatchNorm3D, Operand<?>, Operand<TBool>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Graph, Ops, Op, Operand<?>...) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, ArgMax, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Cast, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Eq, Operand<?>, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Get, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Input) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Mean, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Conv2D, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Conv3D, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, ConvLSTM2D, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, CrossEntropyLoss, Operand<?>, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Linear, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, MSELoss, Operand<?>, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, ReLU, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Sigmoid, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Softmax, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Reshape, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Slice, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, Transpose, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- convert(Ops, ZeroLike, Operand<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- Convertor - Class in org.apache.wayang.tensorflow.model
- Convertor() - Constructor for class org.apache.wayang.tensorflow.model.Convertor
- convertToByte() - Method in class org.apache.wayang.flink.compiler.criterion.WayangValue
- convertToJavaTimestamp(long) - Static method in class org.apache.wayang.profiler.util.RrdAccessor
- convertToObject(byte[]) - Method in class org.apache.wayang.flink.compiler.criterion.WayangValue
- convertToUnixTimestamp(long) - Static method in class org.apache.wayang.profiler.util.RrdAccessor
- convertWithConfig(RelNode, Configuration, Collection<Record>) - Method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- convertWithoutFixCosts(TimeEstimate) - Method in class org.apache.wayang.core.optimizer.costs.TimeToCostConverter
-
Convert the given
TimeEstimate
into a cost estimate without considering the fix costs. - ConvLSTM2D - Class in org.apache.wayang.basic.model.op.nn
- ConvLSTM2D(int, int, int[], int[], boolean, String) - Constructor for class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- ConvLSTM2D(int, int, int[], int[], boolean, String, String) - Constructor for class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- ConvLSTM2D(int, int, int[], int[], boolean, String, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- ConvLSTM2D(int, int, int[], int[], boolean, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- copy() - Method in class org.apache.wayang.basic.channels.FileChannel
- copy() - Method in class org.apache.wayang.basic.data.Record
- copy() - Method in class org.apache.wayang.core.optimizer.costs.ConstantLoadProfileEstimator
- copy() - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Optional operation. Copy this instance.
- copy() - Method in class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
- copy() - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Create a shallow copy of this instance.
- copy() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Create a copy of this instance.
- copy() - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
- copy() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- copy() - Method in interface org.apache.wayang.core.util.Copyable
-
Create a (potentially shallow) copy of this instance.
- copy() - Method in class org.apache.wayang.flink.channels.DataSetChannel
- copy() - Method in class org.apache.wayang.java.channels.CollectionChannel
- copy() - Method in class org.apache.wayang.java.channels.StreamChannel
- copy() - Method in class org.apache.wayang.java.operators.JavaAmazonS3Source
- copy() - Method in class org.apache.wayang.java.operators.JavaAzureBlobStorageSource
- copy() - Method in class org.apache.wayang.java.operators.JavaGoogleCloudStorageSource
- copy() - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSource
- copy() - Method in class org.apache.wayang.java.operators.JavaTextFileSource
- copy() - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel
- copy() - Method in class org.apache.wayang.spark.channels.BroadcastChannel
- copy() - Method in class org.apache.wayang.spark.channels.RddChannel
- copy() - Method in class org.apache.wayang.tensorflow.channels.TensorChannel
- copy(RelTraitSet, RelNode, List<RexNode>, RelDataType) - Method in class org.apache.wayang.api.sql.calcite.rel.WayangProject
- copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.wayang.api.sql.calcite.rel.WayangSort
- copy(RelTraitSet, RelNode, RexNode) - Method in class org.apache.wayang.api.sql.calcite.rel.WayangFilter
- copy(RelTraitSet, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.wayang.api.sql.calcite.rel.WayangAggregate
- copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.wayang.api.sql.calcite.rel.WayangJoin
- Copyable<Self> - Interface in org.apache.wayang.core.util
-
Implementing objects must be able to provide copies of themselves.
- copyAsNonBroadcastFor(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
-
As
InputSlot.copyFor(Operator)
, but ensures that the copy will not be marked as broadcast. - copyFor(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Shortcut for
InputSlot(Slot, Operator)
- copyFor(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
- copyFrom(MathExParser.ExpressionContext) - Method in class org.apache.wayang.core.mathex.MathExParser.ExpressionContext
- copyNames(SubplanMatch, Operator) - Method in class org.apache.wayang.core.mapping.ReplacementSubplanFactory
- CORES_PROPERTY - Static variable in class org.apache.wayang.giraph.platform.GiraphPlatform
- coresProperty - Variable in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- CORRECTNESS_PROBABILITY - Static variable in class org.apache.wayang.basic.operators.AmazonS3Source.CardinalityEstimator
- CORRECTNESS_PROBABILITY - Static variable in class org.apache.wayang.basic.operators.AzureBlobStorageSource.CardinalityEstimator
- CORRECTNESS_PROBABILITY - Static variable in class org.apache.wayang.basic.operators.GoogleCloudStorageSource.CardinalityEstimator
- CORRECTNESS_PROBABILITY - Static variable in class org.apache.wayang.basic.operators.KafkaTopicSource.CardinalityEstimator
- CORRECTNESS_PROBABILITY - Static variable in class org.apache.wayang.basic.operators.ObjectFileSource.CardinalityEstimator
- CORRECTNESS_PROBABILITY - Static variable in class org.apache.wayang.basic.operators.TextFileSource.CardinalityEstimator
- CostbasedTreeSelectionStrategy() - Constructor for class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph.CostbasedTreeSelectionStrategy
- CostMeasurement - Class in org.apache.wayang.core.profiling
-
This measurement captures execution costs w.r.t. to Wayang's cost model.
- CostMeasurement() - Constructor for class org.apache.wayang.core.profiling.CostMeasurement
-
Deserialization constructor.
- CostMeasurement(String, double, double, double) - Constructor for class org.apache.wayang.core.profiling.CostMeasurement
-
Creates a new instance.
- COUNT_ORDER - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- Counter<T> - Class in org.apache.wayang.core.util
-
This utility helps to count elements.
- Counter() - Constructor for class org.apache.wayang.core.util.Counter
- CountMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
CountOperator
toFlinkCountOperator
. - CountMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
CountOperator
toJavaCountOperator
. - CountMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
CountOperator
toSparkCountOperator
. - CountMapping() - Constructor for class org.apache.wayang.flink.mapping.CountMapping
- CountMapping() - Constructor for class org.apache.wayang.java.mapping.CountMapping
- CountMapping() - Constructor for class org.apache.wayang.spark.mapping.CountMapping
- CountOperator<Type> - Class in org.apache.wayang.basic.operators
-
This operator returns the count of elements in this stream.
- CountOperator(Class<Type>) - Constructor for class org.apache.wayang.basic.operators.CountOperator
-
Creates a new instance.
- CountOperator(CountOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.CountOperator
-
Copies an instance (exclusive of broadcasts).
- CountOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.CountOperator
-
Creates a new instance.
- CPU_MHZ_PROPERTY - Static variable in class org.apache.wayang.giraph.platform.GiraphPlatform
- cpuConverter - Variable in class org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter
- cpuMhz - Variable in class org.apache.wayang.profiler.java.OperatorProfiler
- cpuMhz - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- cpuMhzProperty - Variable in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- create(String) - Method in interface org.apache.wayang.core.util.fs.FileSystem
-
Opens the file specified in the given
url
for (over-)writing. - create(String) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- create(String) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- create(String) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- create(String, Boolean) - Method in interface org.apache.wayang.core.util.fs.FileSystem
-
Opens the file specified in the given
url
for (over-)writing. - create(String, Boolean) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- create(String, Boolean) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- create(String, Boolean) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- create(String, String[]) - Static method in class org.apache.wayang.basic.operators.ParquetSource
-
Creates a new instance.
- create(CalciteSchema, Properties, RelDataTypeFactory) - Static method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- create(RelOptCluster, RelOptTable) - Static method in class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- create(RelOptCluster, RelOptTable, int[]) - Static method in class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- create(SchemaPlus, String, Map<String, Object>) - Static method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
-
Creates a JdbcSchema, taking credentials from a map.
- create(SchemaPlus, String, Map<String, Object>) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema.Factory
- create(SchemaPlus, String, DataSource, String, String) - Static method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- create(SchemaPlus, String, DataSource, SqlDialectFactory, String, String) - Static method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- create(WayangSchema) - Static method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- create(Job) - Method in interface org.apache.wayang.core.platform.Executor.Factory
- createAlternative() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- createBasic(Class<T>) - Static method in class org.apache.wayang.core.types.DataUnitType
- createBasicUnchecked(Class<?>) - Static method in class org.apache.wayang.core.types.DataUnitType
- createBlockInfo() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.CartesianOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.CoGroupOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.CollectionSource
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.CountOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.DecisionTreeRegressionOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.DistinctOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.FilterOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.FlatMapOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.GlobalReduceOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.IntersectOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.JoinOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.KafkaTopicSource
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.KMeansOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.LinearRegressionOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.LinearSVCOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.LocalCallbackSink
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.LogisticRegressionOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.LoopOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.MapOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.MapPartitionsOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.MaterializedGroupByOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.ObjectFileSource
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.PageRankOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.ParquetSource
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.ReduceByOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.ReduceOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.SampleOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.SortOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.TextFileSource
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.UnionAllOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.basic.operators.ZipWithIdOperator
- createCardinalityEstimator(int, Configuration) - Method in interface org.apache.wayang.core.plan.wayangplan.ElementaryOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.flink.operators.FlinkCollectionSink
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.java.operators.JavaCollectOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.spark.operators.SparkCacheOperator
- createCardinalityEstimator(int, Configuration) - Method in class org.apache.wayang.spark.operators.SparkCollectOperator
- createChannel(OutputSlot<?>, Configuration) - Method in class org.apache.wayang.core.platform.ChannelDescriptor
-
Creates a new
Channel
as described by this instance. - createChannelInstance() - Static method in class org.apache.wayang.profiler.java.OperatorProfiler
- createChannelInstance(Collection<?>) - Static method in class org.apache.wayang.profiler.java.OperatorProfiler
- createChannelInstance(JavaRDD<?>, SparkExecutor) - Static method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Creates a
ChannelInstance
that carries the givenrdd
. - createChannelInstance(SparkExecutor) - Static method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Creates an empty
ChannelInstance
. - createCollectingJavaLocalCallbackSinkProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createCollectingSink(Collection<T>, Class<T>) - Static method in class org.apache.wayang.basic.operators.LocalCallbackSink
- createCollectingSink(Collection<T>, DataSetType<T>) - Static method in class org.apache.wayang.basic.operators.LocalCallbackSink
- createConcatenationKey(OutputSlot<?>, OptimizationContext) - Static method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
- createCopy() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkCartesianOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkCollectionSource
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkCountOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkDistinctOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkGroupByOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkIntersectOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkJoinOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkLoopOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkMapOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSink
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSource
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkReduceByOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkRepeatOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkSampleOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkSortOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkTextFileSource
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkTsvFileSink
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkUnionAllOperator
- createCopy() - Method in class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
- createCopy() - Method in class org.apache.wayang.genericjdbc.operators.GenericJdbcFilterOperator
- createCopy() - Method in class org.apache.wayang.genericjdbc.operators.GenericJdbcProjectionOperator
- createCopy() - Method in class org.apache.wayang.iejoin.operators.JavaIEJoinOperator
- createCopy() - Method in class org.apache.wayang.iejoin.operators.JavaIESelfJoinOperator
- createCopy() - Method in class org.apache.wayang.iejoin.operators.SparkIEJoinOperator
- createCopy() - Method in class org.apache.wayang.iejoin.operators.SparkIESelfJoinOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaCartesianOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaCoGroupOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaCollectionSource
- createCopy() - Method in class org.apache.wayang.java.operators.JavaCountOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaDistinctOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaDoWhileOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaFilterOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaFlatMapOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaIntersectOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaJoinOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaLocalCallbackSink
- createCopy() - Method in class org.apache.wayang.java.operators.JavaLoopOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaMapOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaMapPartitionsOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaObjectFileSink
- createCopy() - Method in class org.apache.wayang.java.operators.JavaObjectFileSource
- createCopy() - Method in class org.apache.wayang.java.operators.JavaRandomSampleOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaReduceByOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaRepeatOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaReservoirSampleOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaSortOperator
- createCopy() - Method in class org.apache.wayang.java.operators.JavaTsvFileSink
- createCopy() - Method in class org.apache.wayang.java.operators.JavaTsvFileSource
- createCopy() - Method in class org.apache.wayang.java.operators.JavaUnionAllOperator
- createCopy() - Method in class org.apache.wayang.postgres.operators.PostgresFilterOperator
- createCopy() - Method in class org.apache.wayang.postgres.operators.PostgresJoinOperator
- createCopy() - Method in class org.apache.wayang.postgres.operators.PostgresProjectionOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkBroadcastOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkCartesianOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkCoGroupOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkCollectionSource
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkCountOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkDistinctOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkDoWhileOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkFlatMapOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkIntersectOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkJoinOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkLocalCallbackSink
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkLoopOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkMapOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkObjectFileSink
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkObjectFileSource
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkReduceByOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkRepeatOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkSortOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkTextFileSource
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkTsvFileSink
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkTsvFileSource
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkUnionAllOperator
- createCopy() - Method in class org.apache.wayang.spark.operators.SparkZipWithIdOperator
- createCopy() - Method in class org.apache.wayang.tensorflow.operators.TensorflowCollectionSource
- createDatabaseDescriptor(Configuration) - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
-
Creates a new
DatabaseDescriptor
for this instance and the givenConfiguration
. - createDatabaseDescriptor(Configuration, String) - Method in class org.apache.wayang.genericjdbc.platform.GenericJdbcPlatform
- createDefault(Class<? extends T>) - Static method in class org.apache.wayang.core.types.DataSetType
-
Creates a flat data set that contains basic data units.
- createDefault(LoadToTimeConverter, LoadToTimeConverter, LoadToTimeConverter, LoadProfileToTimeConverter.ResourceTimeEstimateAggregator) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter
-
Create an instance that adds up
TimeEstimate
s of givenLoadProfile
s including their sub-LoadProfile
s by adding upTimeEstimate
s of the same type and otherwise using the given objects to do the conversion. - createDefault(BasicDataUnitType<T>) - Static method in class org.apache.wayang.core.types.DataSetType
-
Creates a flat data set that contains basic data units.
- createDefaultUnchecked(Class<?>) - Static method in class org.apache.wayang.core.types.DataSetType
-
Creates a flat data set that contains basic data units.
- createDialect(DataSource) - Static method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
-
Deprecated.
- createDialect(SqlDialectFactory, DataSource) - Static method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
-
Returns a suitable SQL dialect for the given data source.
- createEstimatorFor(LoadProfileEstimator, Configuration, OptimizationSpace) - Static method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimators
-
Creates a
DynamicLoadProfileEstimator
according to the givenLoadProfileEstimator
and its nestedLoadProfileEstimator
s. - createExecutor(Job) - Method in class org.apache.wayang.core.platform.Platform
-
Shortcut. Creates an
Executor
using thePlatform.getExecutorFactory()
. - createFallback(int, int) - Static method in class org.apache.wayang.core.optimizer.costs.LoadEstimator
-
Create a fallback instance.
- createFor(String, String, String, OptimizationSpace) - Static method in class org.apache.wayang.profiler.log.DynamicLoadEstimator
-
Parses a mathematical expression and provides it as a
LoadEstimator.SinglePointEstimationFunction
. - createFor(OperatorContainer, Configuration) - Static method in class org.apache.wayang.core.optimizer.cardinality.SubplanCardinalityPusher
-
Create an instance for the given
Subplan
. - createFor(WayangPlan, String) - Static method in class org.apache.wayang.core.plan.wayangplan.PlanMetrics
-
Creates a new instance and collects metrics from the given
WayangPlan
. - createForRecords(RecordType, String...) - Static method in class org.apache.wayang.basic.function.ProjectionDescriptor
-
Creates a new instance that specifically projects
Record
s. - createFrom(Job) - Static method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Create a new instance and adds all
Operator
s in theWayangPlan
. - createFrom(ExecutionTaskFlow, StageAssignmentTraversal.StageSplittingCriterion) - Static method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
Creates a new instance from the given
ExecutionTaskFlow
. - createFrom(PlanImplementation) - Static method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow
- createFromJuelSpecification(String, WayangJsonObj) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileEstimators
-
Creates a new instance from a specification
String
. - createFromMathExSpecification(String, WayangJsonObj) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileEstimators
-
Creates a new instance from a specification
String
. - createFromMeasurement(long, Collection<ExecutionLineageNode>, Configuration) - Static method in class org.apache.wayang.core.platform.PartialExecution
-
Creates a new instance according to the measurement data.
- createFromSpecification(String, String) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileEstimators
-
Creates a new instance from a specification
String
. - createFromSpecification(String, Configuration) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileEstimators
-
Creates an
LoadProfileEstimator
via a specification that is retrieved from aConfiguration
. - createFromTemplate(String, String, OptimizationSpace) - Static method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimators
-
Creates a new instance from a template
String
. - createGrouped(Class<? extends T>) - Static method in class org.apache.wayang.core.types.DataSetType
-
Creates a data set that contains groups of data units.
- createGrouped(Class<T>) - Static method in class org.apache.wayang.core.types.DataUnitType
- createGrouped(BasicDataUnitType<T>) - Static method in class org.apache.wayang.core.types.DataSetType
-
Creates a new data set type that contains groups of data units.
- createGroupedReduce(ReduceDescriptor<Type>, DataSetType<? extends Iterable<Type>>, DataSetType<Type>) - Static method in class org.apache.wayang.basic.operators.ReduceOperator
-
Deprecated.This method is just a hack that is necessary because of the ambiguous nature of this operator.
- createGroupedUnchecked(Class<?>) - Static method in class org.apache.wayang.core.types.DataSetType
-
Creates a data set that contains groups of data units.
- createGroupedUnchecked(Class<?>) - Static method in class org.apache.wayang.core.types.DataUnitType
- createIdentityMapping(Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- createInitialPopulation() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
-
Creates a population of random
Individual
s. - createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.basic.channels.FileChannel
- createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Create a
ChannelInstance
for this instance. - createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.flink.channels.DataSetChannel
- createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.java.channels.CollectionChannel
- createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.java.channels.StreamChannel
- createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel
- createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.spark.channels.BroadcastChannel
- createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.spark.channels.RddChannel
- createInstance(Executor, OptimizationContext.OperatorContext, int) - Method in class org.apache.wayang.tensorflow.channels.TensorChannel
- createIOLinearEstimator(long, double) - Static method in class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
-
Create a fallback
LoadEstimator
that accounts a given load for each input and output element. - createIOLinearEstimator(ExecutionOperator, long, double) - Static method in class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
-
Create a
LoadEstimator
that accounts a given load for each input and output element. - createIOLinearEstimator(ExecutionOperator, long, double, CardinalityEstimate) - Static method in class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
-
Create a
LoadEstimator
that accounts a given load for each input and output element. - createIOLinearEstimator(T, long, long, double, CardinalityEstimate) - Static method in class org.apache.wayang.core.optimizer.costs.IntervalLoadEstimator
-
Create a
LoadEstimator
that accounts a given load for each input and output element. - createJavaCartesianProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaCollectionSourceProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaCountProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaCountProfiler(Supplier<T>, Class<T>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaDistinctProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaDistinctProfiler(Supplier<T>, Class<T>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaFilterProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaFlatMapProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaFlatMapProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Iterable<Out>>, Class<In>, Class<Out>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaGlobalReduceProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaGlobalReduceProfiler(Supplier<In>, FunctionDescriptor.SerializableBinaryOperator<In>, Class<In>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaJoinProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaLocalCallbackSinkProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaMapProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaMapProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Out>, Class<In>, Class<Out>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaMaterializedGroupByProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaMaterializedGroupByProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Key>, Class<In>, Class<Key>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaReduceByProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaReduceByProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Key>, FunctionDescriptor.SerializableBinaryOperator<In>, Class<In>, Class<Key>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaSortProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaSortProfiler(Supplier<T>, Class<T>) - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaTextFileSourceProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJavaUnionProfiler() - Static method in class org.apache.wayang.profiler.java.OperatorProfilers
- createJdbcConnection() - Method in class org.apache.wayang.jdbc.execution.DatabaseDescriptor
-
Creates a
Connection
to the database described by this instance. - createJob(String, Monitor, WayangPlan, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Create a new
Job
that should execute the givenWayangPlan
eventually. - createJob(String, WayangPlan, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Create a new
Job
that should execute the givenWayangPlan
eventually. - createJob(String, WayangPlan, Experiment, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Create a new
Job
that should execute the givenWayangPlan
eventually. - createKey(Operator, OptimizationContext) - Static method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- createLinearCoverter(double) - Static method in class org.apache.wayang.core.optimizer.costs.LoadToTimeConverter
-
Create linear converter.
- createLoadProfileEstimator(Configuration) - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Developers of
ExecutionOperator
s can provide a defaultLoadProfileEstimator
via this method. - createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkFilterOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkGroupByOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkJoinOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkMapOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkReduceByOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.flink.operators.FlinkTextFileSink
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaCoGroupOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaDoWhileOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaFilterOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaFlatMapOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaGlobalReduceOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaJoinOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSink
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaLoopOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaMapOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaMapPartitionsOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaReduceByOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.java.operators.JavaTextFileSink
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.jdbc.operators.JdbcFilterOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.jdbc.operators.JdbcJoinOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.jdbc.operators.JdbcProjectionOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkDoWhileOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkFilterOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkFlatMapOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkJoinOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkLoopOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkMapOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkReduceByOperator
- createLoadProfileEstimator(Configuration) - Method in class org.apache.wayang.spark.operators.SparkTextFileSink
- createLoadProfileEstimators(Configuration, Collection<String>) - Static method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Creates a
LoadProfileEstimator
according to theConfiguration
. - createLoadProfileToTimeConverter(Configuration) - Method in class org.apache.wayang.core.platform.Platform
- createLoadProfileToTimeConverter(Configuration) - Method in class org.apache.wayang.flink.platform.FlinkPlatform
- createLoadProfileToTimeConverter(Configuration) - Method in class org.apache.wayang.giraph.platform.GiraphPlatform
- createLoadProfileToTimeConverter(Configuration) - Method in class org.apache.wayang.java.platform.JavaPlatform
- createLoadProfileToTimeConverter(Configuration) - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- createLoadProfileToTimeConverter(Configuration) - Method in class org.apache.wayang.spark.platform.SparkPlatform
- createLoadProfileToTimeConverter(Configuration) - Method in class org.apache.wayang.tensorflow.platform.TensorflowPlatform
- createMap(Tuple<K, V>...) - Static method in class org.apache.wayang.core.util.WayangCollections
- createNullFilledArrayList(int) - Static method in class org.apache.wayang.core.util.WayangCollections
- createOutputChannelInstances(Executor, ExecutionTask, OptimizationContext.OperatorContext, List<ChannelInstance>) - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Create output
ChannelInstance
s for this instance. - createPartialExecution(Collection<ExecutionLineageNode>, long) - Method in class org.apache.wayang.core.platform.ExecutorTemplate
-
Create a
PartialExecution
according to the given parameters. - createPowerList(Collection<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Creates the power list of the given
base
(akin to power sets of sets). - createPowerList(Collection<T>, int) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Creates the power list of the given
base
(akin to power sets of sets). - createProfileDB() - Static method in class org.apache.wayang.core.profiling.ProfileDBs
-
Create and customize a
ProfileDB
. - createProjection(Class<Input>, Class<Output>, String...) - Static method in class org.apache.wayang.basic.operators.MapOperator
-
Creates a new instance that projects the given fields.
- createProjection(RecordType, String...) - Static method in class org.apache.wayang.basic.operators.MapOperator
-
Creates a new instance that projects the given fields of
Record
s. - createPruningStrategy(Class<T>, Configuration) - Static method in class org.apache.wayang.core.optimizer.OptimizationUtils
-
Creates a new
PlanEnumerationPruningStrategy
and configures it. - createPushTraversal(Collection<InputSlot<?>>, Collection<InputSlot<?>>, Collection<Operator>, Configuration) - Static method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimationTraversal
-
Create an instance that pushes
CardinalityEstimate
s through a data flow plan starting at the giveninputSlots
andsourceOperators
, thereby puttingCardinalityEstimate
s into thecache
. - createPushTraversal(Collection<InputSlot<?>>, Collection<Operator>, Configuration) - Static method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimationTraversal
-
Create an instance that pushes
CardinalityEstimate
s through a data flow plan starting at the giveninputSlots
andsourceOperators
, thereby puttingCardinalityEstimate
s into thecache
. - createPushTraversal(OperatorContainer, Configuration) - Static method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimationTraversal
-
Create an instance that pushes
CardinalityEstimate
s through a data flow plan starting at the giveninputSlots
andsourceOperators
, thereby puttingCardinalityEstimate
s into thecache
. - createRandomIndividual(Random) - Method in class org.apache.wayang.profiler.log.OptimizationSpace
- createRandomIntegerSupplier(int, int, Random) - Static method in class org.apache.wayang.profiler.data.DataGenerators
- createRandomIntegerSupplier(Random) - Static method in class org.apache.wayang.profiler.data.DataGenerators
- createRandomStringSupplier(int, int, Random) - Static method in class org.apache.wayang.profiler.data.DataGenerators
- createRandomValue(Random) - Method in class org.apache.wayang.profiler.log.Variable
- createReplacementSubplan(SubplanMatch, int) - Method in class org.apache.wayang.core.mapping.ReplacementSubplanFactory
- createReservoirBasedIntegerSupplier(List<Integer>, double, Random) - Static method in class org.apache.wayang.profiler.data.DataGenerators
- createReservoirBasedStringSupplier(List<String>, double, Random, int, int) - Static method in class org.apache.wayang.profiler.data.DataGenerators
- createSingleton(OperatorPattern) - Static method in class org.apache.wayang.core.mapping.SubplanPattern
-
Creates a new instance that matches only a single operator.
- createSparkCartesianProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkCartesianOperator
profiler. - createSparkCartesianProfiler(Supplier<In0>, Supplier<In1>, Class<In0>, Class<In1>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkCartesianOperator
profiler. - createSparkCollectionSourceProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Create a default
SparkCollectionSource
profiler. - createSparkCollectionSourceProfiler(Supplier<String>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Create a custom
SparkTextFileSource
profiler. - createSparkCountProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkCountOperator
profiler. - createSparkCountProfiler(Supplier<In>, Class<In>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkCountOperator
profiler. - createSparkDistinctProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkDistinctOperator
profiler. - createSparkDistinctProfiler(Supplier<Type>, Class<Type>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkGlobalReduceOperator
profiler. - createSparkFilterProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkFilterOperator
profiler. - createSparkFilterProfiler(Supplier<Type>, FunctionDescriptor.SerializablePredicate<Type>, Class<Type>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkMapOperator
profiler. - createSparkFlatMapProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkFlatMapOperator
profiler. - createSparkFlatMapProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Iterable<Out>>, Class<In>, Class<Out>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkFlatMapOperator
profiler. - createSparkGlobalReduceProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkGlobalReduceOperator
profiler. - createSparkGlobalReduceProfiler(Supplier<Type>, FunctionDescriptor.SerializableBinaryOperator<Type>, Class<Type>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkGlobalReduceOperator
profiler. - createSparkJoinProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkJoinOperator
profiler. - createSparkJoinProfiler(Supplier<In0>, Class<In0>, FunctionDescriptor.SerializableFunction<In0, Key>, Supplier<In1>, Class<In1>, FunctionDescriptor.SerializableFunction<In1, Key>, Class<Key>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkJoinOperator
profiler. - createSparkLocalCallbackSinkProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkLocalCallbackSink
profiler. - createSparkLocalCallbackSinkProfiler(Supplier<Type>, Class<Type>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkLocalCallbackSink
profiler. - createSparkMapProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkMapOperator
profiler. - createSparkMapProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Out>, Class<In>, Class<Out>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkMapOperator
profiler. - createSparkMaterializedGroupByProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkMaterializedGroupByOperator
profiler. - createSparkMaterializedGroupByProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Key>, Class<In>, Class<Key>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkMaterializedGroupByOperator
profiler. - createSparkReduceByProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkReduceByOperator
profiler. - createSparkReduceByProfiler(Supplier<In>, FunctionDescriptor.SerializableFunction<In, Key>, FunctionDescriptor.SerializableBinaryOperator<In>, Class<In>, Class<Key>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkReduceByOperator
profiler. - createSparkSortProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkSortOperator
profiler. - createSparkSortProfiler(Supplier<Type>, Class<Type>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkSortOperator
profiler. - createSparkTextFileSourceProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Create a default
SparkTextFileSource
profiler. - createSparkTextFileSourceProfiler(Supplier<String>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Create a custom
SparkTextFileSource
profiler. - createSparkUnionProfiler() - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a default
SparkUnionAllOperator
profiler. - createSparkUnionProfiler(Supplier<Type>, Supplier<Type>, Class<Type>, Configuration) - Static method in class org.apache.wayang.profiler.spark.OperatorProfilers
-
Creates a custom
SparkUnionAllOperator
profiler. - createSqlClause(Connection, FunctionCompiler) - Method in interface org.apache.wayang.jdbc.operators.JdbcExecutionOperator
-
Creates a SQL clause for this instance.
- createSqlClause(Connection, FunctionCompiler) - Method in class org.apache.wayang.jdbc.operators.JdbcFilterOperator
- createSqlClause(Connection, FunctionCompiler) - Method in class org.apache.wayang.jdbc.operators.JdbcJoinOperator
- createSqlClause(Connection, FunctionCompiler) - Method in class org.apache.wayang.jdbc.operators.JdbcProjectionOperator
- createSqlClause(Connection, FunctionCompiler) - Method in class org.apache.wayang.jdbc.operators.JdbcTableSource
- createSqlQuery(String, Collection<String>, String) - Method in class org.apache.wayang.genericjdbc.execution.GenericJdbcExecutor
-
Creates a SQL query.
- createSqlQuery(ExecutionStage, OptimizationContext) - Method in class org.apache.wayang.jdbc.execution.JdbcExecutor
-
Creates a query channel and the sql statement
- createStage(ExecutionStageLoop, int) - Method in class org.apache.wayang.core.plan.executionplan.PlatformExecution
- createStdoutSink(Class<T>) - Static method in class org.apache.wayang.basic.operators.LocalCallbackSink
- createStdoutSink(DataSetType<T>) - Static method in class org.apache.wayang.basic.operators.LocalCallbackSink
- createTimeToCostConverter(Configuration) - Method in class org.apache.wayang.core.platform.Platform
-
Creates a
TimeToCostConverter
for this instance. - createTimeToCostConverter(Configuration) - Method in class org.apache.wayang.flink.platform.FlinkPlatform
- createTimeToCostConverter(Configuration) - Method in class org.apache.wayang.giraph.platform.GiraphPlatform
- createTimeToCostConverter(Configuration) - Method in class org.apache.wayang.java.platform.JavaPlatform
- createTimeToCostConverter(Configuration) - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- createTimeToCostConverter(Configuration) - Method in class org.apache.wayang.spark.platform.SparkPlatform
- createTimeToCostConverter(Configuration) - Method in class org.apache.wayang.tensorflow.platform.TensorflowPlatform
- createTopLevelStretching(LoadToTimeConverter, LoadToTimeConverter, LoadToTimeConverter, LoadProfileToTimeConverter.ResourceTimeEstimateAggregator, double) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter
-
Create an instance that adds up
TimeEstimate
s of givenLoadProfile
s including their sub-LoadProfile
s by adding upTimeEstimate
s of the same type and otherwise using the given objects to do the conversion. - createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexInputFormat
- createVertexWriter(TaskAttemptContext) - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexOutputFormat
- createWayangPlan(String, Collection<Tuple2<String, Integer>>) - Static method in class org.apache.wayang.apps.wordcount.WordCountWithJavaNativeAPI
-
Creates the
WayangPlan
for the word count app. - criterionDescriptor - Variable in class org.apache.wayang.basic.operators.DoWhileOperator
-
Function that this operator applies to the input elements.
- criterionDescriptor - Variable in class org.apache.wayang.basic.operators.LoopOperator
-
Function that this operator applies to the input elements.
- CrossEntropyLoss - Class in org.apache.wayang.basic.model.op.nn
- CrossEntropyLoss(int) - Constructor for class org.apache.wayang.basic.model.op.nn.CrossEntropyLoss
- CrossEntropyLoss(int, String) - Constructor for class org.apache.wayang.basic.model.op.nn.CrossEntropyLoss
- crossOver(Individual, Random) - Method in class org.apache.wayang.profiler.log.Individual
- CrossPlatformExecutor - Class in org.apache.wayang.core.platform
-
Executes a (cross-platform)
ExecutionPlan
. - CrossPlatformExecutor(Job, InstrumentationStrategy) - Constructor for class org.apache.wayang.core.platform.CrossPlatformExecutor
- CrossProductIterable<T> - Class in org.apache.wayang.core.util
-
Iterates all combinations, i.e., the Cartesian product, of given
Iterable
s. - CrossProductIterable(List<? extends Iterable<T>>) - Constructor for class org.apache.wayang.core.util.CrossProductIterable
- CsvRowConverter - Class in org.apache.wayang.api.sql.sources.fs
-
Based on Calcite's CSV enumerator.
- CsvRowConverter() - Constructor for class org.apache.wayang.api.sql.sources.fs.CsvRowConverter
- customize(ProfileDB) - Static method in class org.apache.wayang.core.profiling.ProfileDBs
-
Customize a
ProfileDB
for use with Wayang.
D
- Dampener(double, double) - Constructor for class org.apache.wayang.flink.operators.FlinkPageRankOperator.Dampener
- dampingFactor - Variable in class org.apache.wayang.basic.operators.PageRankOperator
- Data<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>> - Class in org.apache.wayang.iejoin.data -
Created by khayyzy on 5/28/16.
- Data(long, Type0, Type1) - Constructor for class org.apache.wayang.iejoin.data.Data
- Data.Comparator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>> - Class in org.apache.wayang.iejoin.data -
Created by khayyzy on 5/28/16.
- DatabaseDescriptor - Class in org.apache.wayang.jdbc.execution
-
This class describes a database.
- DatabaseDescriptor(String, String, String, String) - Constructor for class org.apache.wayang.jdbc.execution.DatabaseDescriptor
-
Creates a new instance.
- DataComparator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input> - Class in org.apache.wayang.iejoin.operators.java_helpers -
Created by khayyzy on 5/28/16.
- DataComparator(boolean, boolean) - Constructor for class org.apache.wayang.iejoin.operators.java_helpers.DataComparator
- DataGenerators - Class in org.apache.wayang.profiler.data
-
Utility to create common data generators.
- DataGenerators() - Constructor for class org.apache.wayang.profiler.data.DataGenerators
- DataGenerators.Generator<T> - Interface in org.apache.wayang.profiler.data
- dataQuantumGenerators - Variable in class org.apache.wayang.profiler.java.OperatorProfiler
- dataQuantumGenerators - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- DATASET_TO_COLLECTION - Static variable in class org.apache.wayang.flink.channels.ChannelConversions
- DATASET_TO_HDFS_TSV - Static variable in class org.apache.wayang.flink.channels.ChannelConversions
- DATASET_TO_OBJECT_FILE - Static variable in class org.apache.wayang.flink.channels.ChannelConversions
- DataSetChannel - Class in org.apache.wayang.flink.channels
-
Describes the situation where one
DataSet
is operated on, producing a furtherDataSet
. - DataSetChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.flink.channels.DataSetChannel
- DataSetChannel.Instance - Class in org.apache.wayang.flink.channels
-
ChannelInstance
implementation forDataSet
s. - datasetSize - Variable in class org.apache.wayang.basic.operators.SampleOperator
-
Size of the dataset to be sampled or 0L if a dataset size is not known.
- DataSetType<T> - Class in org.apache.wayang.core.types
-
A data set is an abstraction of the Wayang programming model.
- DataSetType() - Constructor for class org.apache.wayang.core.types.DataSetType
- DataSetType(DataUnitType<T>) - Constructor for class org.apache.wayang.core.types.DataSetType
- dataSource(String, String, String, String) - Static method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
-
Creates a JDBC data source with the given specification.
- DataUnitGroupType<T> - Class in org.apache.wayang.core.types
-
A grouped data unit type describes just the structure of data units within a grouped dataset.
- DataUnitGroupType(DataUnitType) - Constructor for class org.apache.wayang.core.types.DataUnitGroupType
- DataUnitType<T> - Class in org.apache.wayang.core.types
-
The type of data types designate the kind of data that are being passed between operators.
- DataUnitType() - Constructor for class org.apache.wayang.core.types.DataUnitType
- decisionTreeClassification() - Static method in class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- decisionTreeClassification() - Static method in class org.apache.wayang.basic.operators.PredictOperators
- DecisionTreeClassificationMapping - Class in org.apache.wayang.spark.mapping.ml
- DecisionTreeClassificationMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.DecisionTreeClassificationMapping
- DecisionTreeClassificationModel - Interface in org.apache.wayang.basic.model
- DecisionTreeClassificationOperator - Class in org.apache.wayang.basic.operators
- DecisionTreeClassificationOperator() - Constructor for class org.apache.wayang.basic.operators.DecisionTreeClassificationOperator
- DecisionTreeClassificationOperator(DecisionTreeClassificationOperator) - Constructor for class org.apache.wayang.basic.operators.DecisionTreeClassificationOperator
- DecisionTreeRegressionMapping - Class in org.apache.wayang.spark.mapping.ml
-
Mapping from
DecisionTreeRegressionOperator
toSparkDecisionTreeRegressionOperator
. - DecisionTreeRegressionMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.DecisionTreeRegressionMapping
- DecisionTreeRegressionModel - Interface in org.apache.wayang.basic.model
- DecisionTreeRegressionOperator - Class in org.apache.wayang.basic.operators
- DecisionTreeRegressionOperator(int, int) - Constructor for class org.apache.wayang.basic.operators.DecisionTreeRegressionOperator
- DecisionTreeRegressionOperator(DecisionTreeRegressionOperator) - Constructor for class org.apache.wayang.basic.operators.DecisionTreeRegressionOperator
- declareLastAdd() - Method in class org.apache.wayang.core.util.ConsumerIteratorAdapter
-
Declare that all elements have been pushed to the producer
Consumer
. - decrement(T) - Method in class org.apache.wayang.core.util.Counter
- deemsComprehensive(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
- DEFAULT_CONFIG - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangSortRule
- DEFAULT_DAMPING_FACTOR - Static variable in class org.apache.wayang.basic.operators.PageRankOperator
- DEFAULT_GRAPH_DENSITIY - Static variable in class org.apache.wayang.basic.operators.PageRankOperator
- DEFAULT_MONITOR_BASE_URL - Static variable in class org.apache.wayang.core.monitor.Monitor
- DEFAULT_MONITOR_BASE_URL_PROPERTY_KEY - Static variable in class org.apache.wayang.core.monitor.Monitor
- DefaultCardinalityEstimator - Class in org.apache.wayang.core.optimizer.cardinality
-
Default implementation of the
CardinalityEstimator
. - DefaultCardinalityEstimator() - Constructor for class org.apache.wayang.core.optimizer.cardinality.DefaultCardinalityEstimator
- DefaultCardinalityEstimator(double, int, boolean, FunctionDescriptor.SerializableToLongBiFunction<long[], Configuration>) - Constructor for class org.apache.wayang.core.optimizer.cardinality.DefaultCardinalityEstimator
- DefaultCardinalityEstimator(double, int, boolean, FunctionDescriptor.SerializableToLongFunction<long[]>) - Constructor for class org.apache.wayang.core.optimizer.cardinality.DefaultCardinalityEstimator
- DefaultCardinalityPusher - Class in org.apache.wayang.core.optimizer.cardinality
-
Default
CardinalityPusher
implementation. - DefaultCardinalityPusher(Operator, int[], int[], KeyValueProvider<OutputSlot<?>, CardinalityEstimator>) - Constructor for class org.apache.wayang.core.optimizer.cardinality.DefaultCardinalityPusher
- DefaultCardinalityPusher(Operator, KeyValueProvider<OutputSlot<?>, CardinalityEstimator>) - Constructor for class org.apache.wayang.core.optimizer.cardinality.DefaultCardinalityPusher
- DefaultChannelConversion - Class in org.apache.wayang.core.optimizer.channels
-
Default implementation of the
ChannelConversion
. - DefaultChannelConversion(ChannelDescriptor, ChannelDescriptor, BiFunction<Channel, Configuration, ExecutionOperator>, String) - Constructor for class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- DefaultChannelConversion(ChannelDescriptor, ChannelDescriptor, Supplier<ExecutionOperator>) - Constructor for class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- DefaultChannelConversion(ChannelDescriptor, ChannelDescriptor, Supplier<ExecutionOperator>, String) - Constructor for class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- DefaultContext - Class in org.apache.wayang.core.util.mathex
-
Default
Context
implementation that can be configured. - DefaultContext() - Constructor for class org.apache.wayang.core.util.mathex.DefaultContext
-
Creates a new instance.
- DefaultContext(Context) - Constructor for class org.apache.wayang.core.util.mathex.DefaultContext
-
Creates a new instance with a parent.
- DefaultEstimatableCost - Class in org.apache.wayang.core.optimizer.costs
- DefaultEstimatableCost() - Constructor for class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
- DefaultEstimatableCost.Factory - Class in org.apache.wayang.core.optimizer.costs
- DefaultLoadEstimator - Class in org.apache.wayang.core.optimizer.costs
-
Implementation of
LoadEstimator
that uses a single-point cost function. - DefaultLoadEstimator(int, int, double, FunctionDescriptor.SerializableToLongBiFunction<long[], long[]>) - Constructor for class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
- DefaultLoadEstimator(int, int, double, CardinalityEstimate, FunctionDescriptor.SerializableToLongBiFunction<long[], long[]>) - Constructor for class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
- DefaultLoadEstimator(int, int, double, CardinalityEstimate, LoadEstimator.SinglePointEstimationFunction) - Constructor for class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
- DefaultOptimizationContext - Class in org.apache.wayang.core.optimizer
-
This implementation of
OptimizationContext
represents a direct mapping fromOptimizationContext.OperatorContext
to executions of the respectiveOperator
s. - DefaultOptimizationContext(Job) - Constructor for class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Create a new instance.
- DefaultOptimizationContext(Job, Operator) - Constructor for class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Creates a new instance.
- DefaultOptimizationContext(OptimizationContext) - Constructor for class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Forks an
DefaultOptimizationContext
by providing a write-layer on top of thebase
. - defaultPlugin() - Static method in class org.apache.wayang.basic.WayangBasics
- defaultSerializer - Static variable in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Default
JsonSerializer
forEstimationContext
s. - delete(String, boolean) - Method in interface org.apache.wayang.core.util.fs.FileSystem
-
Deletes the given file at the given
url
. - delete(String, boolean) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- delete(String, boolean) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- delete(String, boolean) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- Descriptor(String, String) - Constructor for class org.apache.wayang.basic.channels.FileChannel.Descriptor
-
Creates a new instance.
- Descriptor(JdbcPlatformTemplate) - Constructor for class org.apache.wayang.jdbc.channels.SqlQueryChannel.Descriptor
- DESCRIPTOR - Static variable in class org.apache.wayang.flink.channels.DataSetChannel
- DESCRIPTOR - Static variable in class org.apache.wayang.java.channels.CollectionChannel
- DESCRIPTOR - Static variable in class org.apache.wayang.java.channels.StreamChannel
- DESCRIPTOR - Static variable in class org.apache.wayang.spark.channels.BroadcastChannel
- DESCRIPTOR - Static variable in class org.apache.wayang.tensorflow.channels.TensorChannel
- DESCRIPTOR_MANY - Static variable in class org.apache.wayang.flink.channels.DataSetChannel
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class org.apache.wayang.commons.util.profiledb.json.MeasurementDeserializer
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase.GsonSerializer
- deserialize(Object) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Deserialize a given JSON datatype.
- deserialize(WayangJsonObj) - Method in class org.apache.wayang.core.platform.AtomicExecution.KeyOrLoadSerializer
- deserialize(WayangJsonObj) - Static method in class org.apache.wayang.core.util.JsonSerializables
- deserialize(WayangJsonObj) - Method in interface org.apache.wayang.core.util.JsonSerializer
-
Deserializes an object.
- deserialize(WayangJsonObj, Class<? extends AtomicExecution>) - Method in class org.apache.wayang.core.platform.AtomicExecution.KeyOrLoadSerializer
- deserialize(WayangJsonObj, Class<? extends AtomicExecutionGroup>) - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup.Serializer
- deserialize(WayangJsonObj, Class<? extends PartialExecution>) - Method in class org.apache.wayang.core.platform.PartialExecution.Serializer
- deserialize(WayangJsonObj, Class<? extends T>) - Method in class org.apache.wayang.core.util.JsonSerializable.Serializer
- deserialize(WayangJsonObj, Class<? extends T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Deserialize a
WayangJsonObj
that should correspond to aJsonSerializable
. - deserialize(WayangJsonObj, Class<? extends T>) - Method in interface org.apache.wayang.core.util.JsonSerializer
-
Deserializes an object.
- deserialize(WayangJsonObj, JsonSerializer<T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
- deserialize(WayangJsonObj, JsonSerializer<T>, Class<? extends T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Deserialize a
WayangJsonObj
with aJsonSerializer
. - deserializeAllAsList(WayangJsonArray) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Deserialize a
WayangJsonArray
according to the rules ofJsonSerializables.deserialize(Object)
. - deserializeAllAsList(WayangJsonArray, Class<T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Deserialize a
WayangJsonArray
according to the rules ofJsonSerializables.deserialize(WayangJsonObj, Class)
. - deserializeAllAsList(WayangJsonArray, JsonSerializer<T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Deserialize a
WayangJsonArray
according to the rules ofJsonSerializables.deserialize(WayangJsonObj, JsonSerializer)
. - deserializeAllAsList(WayangJsonArray, JsonSerializer<T>, Class<T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Deserialize a
WayangJsonArray
according to the rules ofJsonSerializables.deserialize(WayangJsonObj, JsonSerializer, Class)
. - dialect - Variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- DisabledMonitor - Class in org.apache.wayang.core.monitor
- DisabledMonitor() - Constructor for class org.apache.wayang.core.monitor.DisabledMonitor
- disconnectFrom(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
- diskCoverter - Variable in class org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter
- DiskProfiler - Class in org.apache.wayang.profiler.hardware
-
Profiles the reading and writing speed to some directory.
- DiskProfiler(String) - Constructor for class org.apache.wayang.profiler.hardware.DiskProfiler
- dispose() - Method in interface org.apache.wayang.core.platform.ExecutionResource
-
Releases the allocated assets of this resource and unregisters it with its
Executor
if there is one. - dispose() - Method in class org.apache.wayang.core.platform.ExecutionResourceTemplate
- dispose() - Method in interface org.apache.wayang.core.platform.Executor
-
Releases any instances acquired by this instance to execute
ExecutionStage
s. - dispose() - Method in class org.apache.wayang.core.platform.ExecutorTemplate
- dispose() - Method in class org.apache.wayang.flink.execution.FlinkExecutor
- dispose() - Method in class org.apache.wayang.genericjdbc.execution.GenericJdbcExecutor
- dispose() - Method in class org.apache.wayang.giraph.execution.GiraphExecutor
- dispose() - Method in class org.apache.wayang.jdbc.execution.JdbcExecutor
- dispose() - Method in class org.apache.wayang.spark.execution.SparkExecutor
- dispose() - Method in class org.apache.wayang.tensorflow.execution.TensorflowExecutor
- disposeIfUnreferenced() - Method in class org.apache.wayang.core.util.AbstractReferenceCountable
- disposeIfUnreferenced() - Method in interface org.apache.wayang.core.util.ReferenceCountable
-
Dispose this instance if there are no more references to it.
- disposeUnreferenced() - Method in class org.apache.wayang.core.platform.ExecutionResourceTemplate
- disposeUnreferenced() - Method in class org.apache.wayang.core.platform.ExecutorTemplate
- disposeUnreferenced() - Method in class org.apache.wayang.core.util.AbstractReferenceCountable
-
Dispose this instance, which is not referenced anymore.
- DistinctMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
DistinctOperator
toFlinkDistinctOperator
. - DistinctMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
DistinctOperator
toJavaDistinctOperator
. - DistinctMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
DistinctOperator
toSparkDistinctOperator
. - DistinctMapping() - Constructor for class org.apache.wayang.flink.mapping.DistinctMapping
- DistinctMapping() - Constructor for class org.apache.wayang.java.mapping.DistinctMapping
- DistinctMapping() - Constructor for class org.apache.wayang.spark.mapping.DistinctMapping
- DistinctOperator<Type> - Class in org.apache.wayang.basic.operators
-
This operator returns the distinct elements in this dataset.
- DistinctOperator(Class<Type>) - Constructor for class org.apache.wayang.basic.operators.DistinctOperator
-
Creates a new instance.
- DistinctOperator(DistinctOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.DistinctOperator
-
Copies an instance (exclusive of broadcasts).
- DistinctOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.DistinctOperator
-
Creates a new instance.
- divideBy(double) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
-
Divides the estimate values, not the probability.
- DLModel - Class in org.apache.wayang.basic.model
- DLModel(Op) - Constructor for class org.apache.wayang.basic.model.DLModel
- DLModel.Builder - Class in org.apache.wayang.basic.model
- DLTrainingOperator<X,
Y> - Class in org.apache.wayang.basic.operators - DLTrainingOperator(DLModel, DLTrainingOperator.Option, Class<X>, Class<Y>) - Constructor for class org.apache.wayang.basic.operators.DLTrainingOperator
- DLTrainingOperator(DLModel, DLTrainingOperator.Option, DataSetType<X>, DataSetType<Y>) - Constructor for class org.apache.wayang.basic.operators.DLTrainingOperator
- DLTrainingOperator(DLTrainingOperator<X, Y>) - Constructor for class org.apache.wayang.basic.operators.DLTrainingOperator
- DLTrainingOperator.Option - Class in org.apache.wayang.basic.operators
- DLTrainingOperatorMapping - Class in org.apache.wayang.tensorflow.mapping
-
Mapping from
DLTrainingOperator
toTensorflowDLTrainingOperator
. - DLTrainingOperatorMapping() - Constructor for class org.apache.wayang.tensorflow.mapping.DLTrainingOperatorMapping
- doDispose() - Method in class org.apache.wayang.basic.channels.FileChannel.Instance
- doDispose() - Method in class org.apache.wayang.core.platform.ExecutionResourceTemplate
-
Performs the actual disposing work of this instance.
- doDispose() - Method in class org.apache.wayang.flink.channels.DataSetChannel.Instance
- doDispose() - Method in class org.apache.wayang.flink.execution.FlinkContextReference
- doDispose() - Method in class org.apache.wayang.java.channels.CollectionChannel.Instance
- doDispose() - Method in class org.apache.wayang.java.channels.StreamChannel.Instance
- doDispose() - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Instance
- doDispose() - Method in class org.apache.wayang.spark.channels.BroadcastChannel.Instance
- doDispose() - Method in class org.apache.wayang.spark.channels.RddChannel.Instance
- doDispose() - Method in class org.apache.wayang.spark.execution.SparkContextReference
- doDispose() - Method in class org.apache.wayang.tensorflow.channels.TensorChannel.Instance
- doDispose() - Method in class org.apache.wayang.tensorflow.execution.TensorflowContextReference
- doExecute() - Method in class org.apache.wayang.core.api.Job
- doExecute() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopEnumerator
- doExecute() - Method in class org.apache.wayang.core.optimizer.enumeration.StageAssignmentTraversal
- doExecute() - Method in class org.apache.wayang.core.plan.wayangplan.LoopIsolator
- doExecute() - Method in class org.apache.wayang.core.platform.PushExecutorTemplate.StageExecution
- doExecute() - Method in class org.apache.wayang.core.util.OneTimeExecutable
-
Performs the actual work of this instance.
- doPush(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.AbstractAlternativeCardinalityPusher
- doPush(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
-
Perform the actual push.
- doPush(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.DefaultCardinalityPusher
- doPush(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.LoopSubplanCardinalityPusher
- doPush(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.SubplanCardinalityPusher
- doSafe(Action) - Static method in class org.apache.wayang.core.util.Actions
-
Executes an
Action
, catching any error. - DoWhileMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
DoWhileOperator
toFlinkDoWhileOperator
. - DoWhileMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
LoopOperator
toJavaLoopOperator
. - DoWhileMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
LoopOperator
toSparkLoopOperator
. - DoWhileMapping() - Constructor for class org.apache.wayang.flink.mapping.DoWhileMapping
- DoWhileMapping() - Constructor for class org.apache.wayang.java.mapping.DoWhileMapping
- DoWhileMapping() - Constructor for class org.apache.wayang.spark.mapping.DoWhileMapping
- DoWhileOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.basic.operators -
This operator has three inputs and two outputs.
- DoWhileOperator(Class<InputType>, Class<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.basic.operators.DoWhileOperator
- DoWhileOperator(DoWhileOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.basic.operators.DoWhileOperator
-
Creates a copy of the given
LoopOperator
. - DoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.basic.operators.DoWhileOperator
- DoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.basic.operators.DoWhileOperator
-
Creates a new instance.
- downstream() - Static method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- doWork() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activator
- doWork() - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activator
-
Performs the work to be done by this instance and defines the next
AbstractTopologicalTraversal.Activation
s. - dType - Variable in class org.apache.wayang.basic.model.op.Op
- DummyFilter<InputType> - Class in org.apache.wayang.flink.compiler.criterion
-
Create a that remove the elements null
- DummyFilter(Class<InputType>) - Constructor for class org.apache.wayang.flink.compiler.criterion.DummyFilter
- DummyMap<InputType,
OutputType> - Class in org.apache.wayang.flink.compiler.criterion -
Class create a that genereta only null as convertion
- DummyMap(Class<InputType>, Class<OutputType>) - Constructor for class org.apache.wayang.flink.compiler.criterion.DummyMap
- DynamicEstimationContext - Class in org.apache.wayang.profiler.log
-
EstimationContext
implementation forDynamicLoadEstimator
s. - DynamicEstimationContext(Individual, EstimationContext) - Constructor for class org.apache.wayang.profiler.log.DynamicEstimationContext
- DynamicLoadEstimator - Class in org.apache.wayang.profiler.log
-
Adjustable
LoadProfileEstimator
implementation. - DynamicLoadEstimator(DynamicLoadEstimator.SinglePointEstimator, Function<Individual, String>, Collection<Variable>) - Constructor for class org.apache.wayang.profiler.log.DynamicLoadEstimator
-
Creates a new instance.
- DynamicLoadEstimator(DynamicLoadEstimator.SinglePointEstimator, Function<Individual, String>, Variable...) - Constructor for class org.apache.wayang.profiler.log.DynamicLoadEstimator
-
Creates a new instance.
- DynamicLoadEstimator.SinglePointEstimator - Interface in org.apache.wayang.profiler.log
- DynamicLoadProfileEstimator - Class in org.apache.wayang.profiler.log
-
Adjustable
LoadProfileEstimator
implementation. - DynamicLoadProfileEstimator(String, int, int, DynamicLoadEstimator) - Constructor for class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
-
Creates a new instance.
- DynamicLoadProfileEstimator(String, int, int, DynamicLoadEstimator, DynamicLoadEstimator, DynamicLoadEstimator) - Constructor for class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
-
Creates a new instance.
- DynamicLoadProfileEstimators - Class in org.apache.wayang.profiler.log
-
Utility to create
DynamicLoadProfileEstimator
s. - DynamicLoadProfileEstimators() - Constructor for class org.apache.wayang.profiler.log.DynamicLoadProfileEstimators
- DynamicPlugin - Class in org.apache.wayang.core.plugin
-
This
Plugin
can be arbitrarily customized. - DynamicPlugin() - Constructor for class org.apache.wayang.core.plugin.DynamicPlugin
E
- ElementaryOperator - Interface in org.apache.wayang.core.plan.wayangplan
- empty() - Method in class org.apache.wayang.api.python.PythonAPI
- empty(Class<T>) - Static method in class org.apache.wayang.basic.operators.CollectionSource
-
Creates a new instance without any data quanta.
- EMPTY_BITMASK - Static variable in class org.apache.wayang.core.util.Bitmask
-
An instance without any bits set.
- EMPTY_ESTIMATE - Static variable in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
- emptyLoadProfile - Static variable in class org.apache.wayang.core.optimizer.costs.LoadProfile
-
Instance with all values set to
0
. - endIteration(Operator, int) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- endIteration(Operator, int, Operator, int) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- endIteration(Operator, int, Operator, int) - Method in class org.apache.wayang.basic.operators.LoopOperator
- endIteration(Operator, Operator) - Method in class org.apache.wayang.basic.operators.LoopOperator
- ensureDir(File) - Static method in class org.apache.wayang.core.util.fs.LocalFileSystem
-
Ensure that there is a directory represented by the given
File
. - ensureInitialized() - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
-
Make sure that this instance is initialized.
- enterBinaryOperation(MathExParser.BinaryOperationContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Enter a parse tree produced by the
binaryOperation
labeled alternative inMathExParser.expression()
. - enterBinaryOperation(MathExParser.BinaryOperationContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Enter a parse tree produced by the
binaryOperation
labeled alternative inMathExParser.expression()
. - enterConstant(MathExParser.ConstantContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Enter a parse tree produced by the
constant
labeled alternative inMathExParser.expression()
. - enterConstant(MathExParser.ConstantContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Enter a parse tree produced by the
constant
labeled alternative inMathExParser.expression()
. - enterEveryRule(ParserRuleContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
- enterFunction(MathExParser.FunctionContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Enter a parse tree produced by the
function
labeled alternative inMathExParser.expression()
. - enterFunction(MathExParser.FunctionContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Enter a parse tree produced by the
function
labeled alternative inMathExParser.expression()
. - enteringContainersIf(Predicate<OperatorContainer>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Criterion to control when to visit the
Operator
s contained inCompositeOperator
s. - enterParensExpression(MathExParser.ParensExpressionContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Enter a parse tree produced by the
parensExpression
labeled alternative inMathExParser.expression()
. - enterParensExpression(MathExParser.ParensExpressionContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Enter a parse tree produced by the
parensExpression
labeled alternative inMathExParser.expression()
. - enterRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- enterRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.ConstantContext
- enterRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- enterRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.ParensExpressionContext
- enterRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.UnaryOperationContext
- enterRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.VariableContext
- enterUnaryOperation(MathExParser.UnaryOperationContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Enter a parse tree produced by the
unaryOperation
labeled alternative inMathExParser.expression()
. - enterUnaryOperation(MathExParser.UnaryOperationContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Enter a parse tree produced by the
unaryOperation
labeled alternative inMathExParser.expression()
. - enterVariable(MathExParser.VariableContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Enter a parse tree produced by the
variable
labeled alternative inMathExParser.expression()
. - enterVariable(MathExParser.VariableContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Enter a parse tree produced by the
variable
labeled alternative inMathExParser.expression()
. - enumerate() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopEnumerator
- enumerate(boolean) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
-
Produce the
PlanEnumeration
for the plan specified during the construction of this instance. - enumerateCombinations(CardinalityEstimate[]) - Method in class org.apache.wayang.core.optimizer.costs.LoadEstimator
-
Create all possible combination of lower and upper estimates of the given
CardinalityEstimate
s, thereby replacingnull
values according toLoadEstimator.replaceNullCardinality(CardinalityEstimate)
. - EnumerationAlternative - Class in org.apache.wayang.core.optimizer.partition
-
An enumeration alternative is embedded within an
EnumerationBranch
. - EnumerationAlternative() - Constructor for class org.apache.wayang.core.optimizer.partition.EnumerationAlternative
- EnumerationBranch - Class in org.apache.wayang.core.optimizer.partition
-
An enumeration branch is the basic unit for enumeration, i.e., translation from a
WayangPlan
to anExecutionPlan
. - EnumerationBranch() - Constructor for class org.apache.wayang.core.optimizer.partition.EnumerationBranch
- epsilon - Variable in class org.apache.wayang.basic.model.op.nn.BatchNorm
- EpsilonFilter() - Constructor for class org.apache.wayang.flink.operators.FlinkPageRankOperator.EpsilonFilter
- Eq - Class in org.apache.wayang.basic.model.op
- Eq() - Constructor for class org.apache.wayang.basic.model.op.Eq
- Eq(String) - Constructor for class org.apache.wayang.basic.model.op.Eq
- equalReverse - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- equalReverse - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- equals(Object) - Method in class org.apache.wayang.apps.tpch.data.q1.GroupKey
- equals(Object) - Method in class org.apache.wayang.basic.channels.FileChannel.Descriptor
- equals(Object) - Method in class org.apache.wayang.basic.data.Record
- equals(Object) - Method in class org.apache.wayang.basic.data.Tuple2
- equals(Object) - Method in class org.apache.wayang.basic.data.Tuple5
- equals(Object) - Method in class org.apache.wayang.basic.types.RecordType
- equals(Object) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- equals(Object) - Method in class org.apache.wayang.commons.util.profiledb.model.Measurement
- equals(Object) - Method in class org.apache.wayang.commons.util.profiledb.model.Subject
- equals(Object) - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- equals(Object) - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- equals(Object) - Method in class org.apache.wayang.core.platform.ChannelDescriptor
- equals(Object) - Method in class org.apache.wayang.core.types.BasicDataUnitType
- equals(Object) - Method in class org.apache.wayang.core.types.DataSetType
- equals(Object) - Method in class org.apache.wayang.core.types.DataUnitGroupType
- equals(Object) - Method in class org.apache.wayang.core.util.Bitmask
- equals(Object) - Method in class org.apache.wayang.core.util.Canonicalizer
- equals(Object) - Method in class org.apache.wayang.core.util.Counter
- equals(Object) - Method in class org.apache.wayang.core.util.Tuple
- equals(Object) - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Descriptor
- equalsWithinDelta(ProbabilisticDoubleInterval, double, long, long) - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
-
Compares with this instance equals with
that
instance within given delta bounds. - equalsWithinDelta(ProbabilisticIntervalEstimate, double, long, long) - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
-
Compares with this instance equals with
that
instance within given delta bounds. - escape(OperatorAlternative.Alternative) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
-
Create a new instance that equals this instance but redirects via
OperatorAlternative.Alternative.getSlotMapping()
. - escape(OperatorAlternative.Alternative, PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Escapes the
OperatorAlternative
that contains this instance. - EstimatableCost - Interface in org.apache.wayang.core.optimizer.costs
-
EstimatableCost defines an interface for optimizer cost in terms of methods to estimate a PlanImplementation's cost.
- EstimatableCostFactory - Interface in org.apache.wayang.core.optimizer.costs
- estimate(EstimationContext) - Method in class org.apache.wayang.core.optimizer.costs.ConstantLoadProfileEstimator
- estimate(EstimationContext) - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Estimates a
LoadProfile
. - estimate(EstimationContext) - Method in class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
- estimate(EstimationContext) - Method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
- estimate(EstimationContext, long[], long[]) - Method in interface org.apache.wayang.core.optimizer.costs.LoadEstimator.SinglePointEstimationFunction
-
Estimate the load for the given artifact, input, and output estimates.
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.basic.operators.AmazonS3Source.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.basic.operators.AzureBlobStorageSource.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.basic.operators.KafkaTopicSource.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.basic.operators.ObjectFileSource.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.basic.operators.ParquetSource.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.basic.operators.TextFileSource.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.core.optimizer.cardinality.AggregatingCardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in interface org.apache.wayang.core.optimizer.cardinality.CardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.core.optimizer.cardinality.DefaultCardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.core.optimizer.cardinality.FallbackCardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.core.optimizer.cardinality.FixedSizeCardinalityEstimator
- estimate(OptimizationContext, CardinalityEstimate...) - Method in class org.apache.wayang.core.optimizer.cardinality.SwitchForwardCardinalityEstimator
- estimate(DynamicEstimationContext, long[], long[]) - Method in interface org.apache.wayang.profiler.log.DynamicLoadEstimator.SinglePointEstimator
- estimateConversionCost(CardinalityEstimate, int, OptimizationContext) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
-
Estimate the required cost to carry out the conversion for a given
cardinality
. - estimateConversionCost(CardinalityEstimate, int, OptimizationContext) - Method in class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- estimateExecutionTime() - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
-
Estimate the
TimeEstimate
for allAtomicExecution
s in this instance. - estimateExecutionTime(EstimationContext) - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
-
Estimate the
TimeEstimate
for allAtomicExecution
s in this instance in the light of the givenEstimationContext
. - estimateLoad() - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
-
Estimate the
LoadProfile
for allAtomicExecution
s in this instance. - estimateLoad(EstimationContext) - Method in class org.apache.wayang.core.platform.AtomicExecution
-
Estimates the
LoadProfile
for this instance under a givenEstimationContext
. - estimateLoad(EstimationContext) - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
-
Estimate the
LoadProfile
for allAtomicExecution
s in this instance in the light of a specificEstimationContext
. - estimateLoadProfile(OptimizationContext.OperatorContext, LoadProfileEstimator) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileEstimators
-
Estimate the
LoadProfile
for anOptimizationContext.OperatorContext
using aLoadProfileEstimator
for the correspondingExecutionOperator
. - EstimationContext - Interface in org.apache.wayang.core.optimizer.costs
-
Provides parameters required by
LoadProfileEstimator
s. - EstimationContextProperty - Annotation Interface in org.apache.wayang.core.plan.wayangplan
-
Marks a property of an
Operator
that is relevant to the estimation process, i.e., should be provided inEstimationContext
s. - evaluate(String) - Static method in interface org.apache.wayang.core.util.mathex.Expression
-
Parse the given
specification
and evaluate it with theContext.baseContext
. - evaluate(String) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Tries to evaluate the given statement, thereby supporting the following statement types:
new <class name>()
<class name>.<constant>
<class name>.<static method>
() - evaluate(String, Context) - Static method in interface org.apache.wayang.core.util.mathex.Expression
-
Parse the given
specification
and evaluate it with the givenContext
. - evaluate(ChannelInstance[], ChannelInstance[]) - Method in class org.apache.wayang.profiler.java.OperatorProfiler
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkCartesianOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkCollectionSink
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkCollectionSource
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkCountOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkDistinctOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.flink.operators.FlinkExecutionOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkFilterOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkGroupByOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkIntersectOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkJoinOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkLoopOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkMapOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSink
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSource
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkReduceByOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkRepeatOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkSampleOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkSortOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkTextFileSink
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkTextFileSource
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkTsvFileSink
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkUnionAllOperator
- evaluate(ChannelInstance[], ChannelInstance[], FlinkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.api.sql.sources.fs.JavaCSVTableSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.iejoin.operators.JavaIEJoinOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.iejoin.operators.JavaIESelfJoinOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.graph.JavaPageRankOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaAmazonS3Source
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaAzureBlobStorageSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaCartesianOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaCoGroupOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaCollectionSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaCollectOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaCountOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaDistinctOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaDoWhileOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.java.operators.JavaExecutionOperator
-
Evaluates this operator.
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaFilterOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaFlatMapOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaGlobalReduceOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaGoogleCloudStorageSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaIntersectOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaJoinOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSink
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaLocalCallbackSink
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaLoopOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaMapOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaMapPartitionsOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaObjectFileSink
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaObjectFileSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaParquetSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaRandomSampleOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaReduceByOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaRepeatOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaReservoirSampleOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaSortOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaTextFileSink
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaTextFileSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaTsvFileSink
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaTsvFileSource
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.java.operators.JavaUnionAllOperator
- evaluate(ChannelInstance[], ChannelInstance[], JavaExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.iejoin.operators.SparkIEJoinOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.iejoin.operators.SparkIESelfJoinOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.jdbc.operators.SqlToRddOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkModelTransformOperator
-
Deprecated.
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.ml.SparkPredictOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkBroadcastOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkCacheOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkCartesianOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkCoGroupOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkCollectionSource
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkCollectOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkCountOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkDistinctOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkDoWhileOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.spark.operators.SparkExecutionOperator
-
Evaluates this operator.
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkFilterOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkFlatMapOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkIntersectOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkJoinOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkLocalCallbackSink
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkLoopOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkMapOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkObjectFileSink
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkObjectFileSource
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkParquetSource
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkReduceByOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkRepeatOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkSortOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkTextFileSink
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkTextFileSource
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkTsvFileSink
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkTsvFileSource
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkUnionAllOperator
- evaluate(ChannelInstance[], ChannelInstance[], SparkExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.spark.operators.SparkZipWithIdOperator
- evaluate(ChannelInstance[], ChannelInstance[], TensorflowExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.tensorflow.operators.TensorflowCollectionSource
- evaluate(ChannelInstance[], ChannelInstance[], TensorflowExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.tensorflow.operators.TensorflowCollectOperator
- evaluate(ChannelInstance[], ChannelInstance[], TensorflowExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.tensorflow.operators.TensorflowDLTrainingOperator
- evaluate(ChannelInstance[], ChannelInstance[], TensorflowExecutor, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.tensorflow.operators.TensorflowExecutionOperator
-
Evaluates this operator.
- evaluate(ChannelInstance[], ChannelInstance[], TensorflowExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.tensorflow.operators.TensorflowPredictOperator
- evaluate(Context) - Method in interface org.apache.wayang.core.util.mathex.Expression
- evaluate(Context) - Method in class org.apache.wayang.core.util.mathex.model.BinaryOperation
- evaluate(Context) - Method in class org.apache.wayang.core.util.mathex.model.CompiledFunction
- evaluate(Context) - Method in class org.apache.wayang.core.util.mathex.model.Constant
- evaluate(Context) - Method in class org.apache.wayang.core.util.mathex.model.NamedFunction
- evaluate(Context) - Method in class org.apache.wayang.core.util.mathex.model.UnaryOperation
- evaluate(Context) - Method in class org.apache.wayang.core.util.mathex.model.Variable
- evaluate(SparkExecutionOperator, ChannelInstance[], ChannelInstance[]) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- EvaluationException - Exception in org.apache.wayang.core.util.mathex.exceptions
-
This exception signals a failed
Expression
evaluation. - EvaluationException() - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.EvaluationException
- EvaluationException(String) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.EvaluationException
- EvaluationException(String, Throwable) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.EvaluationException
- EvaluationException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.EvaluationException
- EvaluationException(Throwable) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.EvaluationException
- evolve(List<Individual>) - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- exchangeInputChannel(Channel, Channel) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
-
Exchanges input
Channel
. - excludeChannelConversion(ChannelConversion) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- excludeMapping(Mapping) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- excludeRequiredPlatform(Platform) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- execute() - Method in class org.apache.wayang.api.python.executor.PythonWorkerManager
- execute() - Method in class org.apache.wayang.core.api.Job
-
Run this instance.
- execute() - Method in interface org.apache.wayang.core.util.Action
-
Perform this action.
- execute() - Method in class org.apache.wayang.core.util.OneTimeExecutable
-
Invoke
OneTimeExecutable.doExecute()
. - execute(String, WayangContext) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- execute(String, Monitor, WayangPlan, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Execute a plan.
- execute(String, WayangPlan, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Execute a plan.
- execute(String, WayangPlan, Experiment, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Execute a plan.
- execute(ExecutionStage, OptimizationContext, ExecutionState) - Method in interface org.apache.wayang.core.platform.Executor
-
Executes the given
stage
. - execute(ExecutionStage, OptimizationContext, ExecutionState) - Method in class org.apache.wayang.core.platform.PushExecutorTemplate
- execute(ExecutionStage, OptimizationContext, ExecutionState) - Method in class org.apache.wayang.genericjdbc.execution.GenericJdbcExecutor
- execute(ExecutionStage, OptimizationContext, ExecutionState) - Method in class org.apache.wayang.giraph.execution.GiraphExecutor
- execute(ExecutionStage, OptimizationContext, ExecutionState) - Method in class org.apache.wayang.jdbc.execution.JdbcExecutor
- execute(ExecutionStage, OptimizationContext, ExecutionState) - Method in class org.apache.wayang.tensorflow.execution.TensorflowExecutor
- execute(ExecutionTask, List<ChannelInstance>, OptimizationContext.OperatorContext, boolean) - Method in class org.apache.wayang.core.platform.PushExecutorTemplate
-
Executes the given
task
and return the outputChannelInstance
s. - execute(ExecutionTask, List<ChannelInstance>, OptimizationContext.OperatorContext, boolean) - Method in class org.apache.wayang.flink.execution.FlinkExecutor
- execute(ExecutionTask, List<ChannelInstance>, OptimizationContext.OperatorContext, boolean) - Method in class org.apache.wayang.java.execution.JavaExecutor
- execute(ExecutionTask, List<ChannelInstance>, OptimizationContext.OperatorContext, boolean) - Method in class org.apache.wayang.spark.execution.SparkExecutor
- execute(WayangPlan, String...) - Method in class org.apache.wayang.core.api.WayangContext
-
Execute a plan.
- execute(ChannelInstance[], ChannelInstance[], GiraphExecutor, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.giraph.operators.GiraphExecutionOperator
-
Evaluates this operator.
- execute(ChannelInstance[], ChannelInstance[], GiraphExecutor, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- executeOperator() - Method in class org.apache.wayang.profiler.java.BinaryOperatorProfiler
- executeOperator() - Method in class org.apache.wayang.profiler.java.OperatorProfiler
-
Executes the profiling task.
- executeOperator() - Method in class org.apache.wayang.profiler.java.SinkProfiler
- executeOperator() - Method in class org.apache.wayang.profiler.java.SourceProfiler
- executeOperator() - Method in class org.apache.wayang.profiler.java.UnaryOperatorProfiler
- executeOperator() - Method in class org.apache.wayang.profiler.spark.BinaryOperatorProfiler
- executeOperator() - Method in class org.apache.wayang.profiler.spark.SinkProfiler
- executeOperator() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Executes the profiling task.
- executeOperator() - Method in class org.apache.wayang.profiler.spark.SparkSourceProfiler
- executeOperator() - Method in class org.apache.wayang.profiler.spark.SparkUnaryOperatorProfiler
- executeSafe() - Method in interface org.apache.wayang.core.util.Action
-
Performs this actionl.
- executeSql(String) - Method in class org.apache.wayang.api.sql.context.SqlContext
- executeStaticArglessMethod(String, String) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Executes a parameterless static method.
- executeUntilBreakpoint(ExecutionPlan, OptimizationContext) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
-
Execute the given
ExecutionPlan
. - ExecutionContext - Interface in org.apache.wayang.core.function
-
While a function is executed on a certain
Platform
, allows access to some information of the context in which the function is being executed. - ExecutionLineageNode - Class in org.apache.wayang.core.platform.lineage
-
Encapsulates
AtomicExecution
s with a commonOptimizationContext.OperatorContext
in a lazy execution lineage. - ExecutionLineageNode(OptimizationContext.OperatorContext) - Constructor for class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
- ExecutionLog - Class in org.apache.wayang.core.profiling
-
Stores execution data have been collected by the
CrossPlatformExecutor
. - ExecutionOperator - Interface in org.apache.wayang.core.plan.wayangplan
-
An execution operator is handled by a certain platform.
- executionPaddingTime - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- ExecutionPlan - Class in org.apache.wayang.core.plan.executionplan
-
Represents an executable, cross-platform data flow.
- ExecutionPlan() - Constructor for class org.apache.wayang.core.plan.executionplan.ExecutionPlan
- ExecutionPlanMeasurement - Class in org.apache.wayang.core.profiling
-
This
Measurement
encapsulates anExecutionPlan
. - ExecutionPlanMeasurement.ChannelNode - Class in org.apache.wayang.core.profiling
-
Encapsulates a
Channel
of theExecutionPlan
. - ExecutionPlanMeasurement.Link - Class in org.apache.wayang.core.profiling
-
A directed link between an
ExecutionPlanMeasurement.OperatorNode
and aExecutionPlanMeasurement.ChannelNode
(in any order). - ExecutionPlanMeasurement.OperatorNode - Class in org.apache.wayang.core.profiling
-
Encapsulates a
Channel
of theExecutionPlan
. - ExecutionResource - Interface in org.apache.wayang.core.platform
-
Represents a resource allocated for execution that needs to be released manually.
- ExecutionResourceTemplate - Class in org.apache.wayang.core.platform
-
Implements various functionalities of an
ExecutionResource
. - ExecutionResourceTemplate(CompositeExecutionResource) - Constructor for class org.apache.wayang.core.platform.ExecutionResourceTemplate
-
Creates a new instance and registers it with an
CompositeExecutionResource
. - ExecutionStage - Class in org.apache.wayang.core.plan.executionplan
-
Resides within a
PlatformExecution
and represents the minimum execution unit that is controlled by Wayang. - ExecutionStageLoop - Class in org.apache.wayang.core.plan.executionplan
-
This class models the execution equivalent of
LoopSubplan
s. - ExecutionStageLoop(LoopSubplan) - Constructor for class org.apache.wayang.core.plan.executionplan.ExecutionStageLoop
- ExecutionState - Interface in org.apache.wayang.core.platform
-
Contains a state of the execution of an
ExecutionTaskFlow
. - ExecutionTask - Class in org.apache.wayang.core.plan.executionplan
-
Serves as an adapter to include
ExecutionOperator
s, which are usually parts ofWayangPlan
s, inExecutionPlan
s. - ExecutionTask(ExecutionOperator) - Constructor for class org.apache.wayang.core.plan.executionplan.ExecutionTask
- ExecutionTask(ExecutionOperator, int, int) - Constructor for class org.apache.wayang.core.plan.executionplan.ExecutionTask
- ExecutionTaskFlow - Class in org.apache.wayang.core.optimizer.enumeration
-
Graph of
ExecutionTask
s andChannel
s. - ExecutionTaskFlow(Collection<ExecutionTask>) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow
- ExecutionTaskFlow(Collection<ExecutionTask>, Set<Channel>) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow
-
Deprecated.
- ExecutionTaskFlowCompiler - Class in org.apache.wayang.core.optimizer.enumeration
-
Creates an
ExecutionTaskFlow
from aPlanImplementation
. - ExecutionTaskFlowCompiler(Collection<ExecutionOperator>, PlanImplementation) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler
-
Creates a new instance that enumerates a complete
ExecutionPlan
. - ExecutionTaskFlowCompiler(Collection<ExecutionOperator>, PlanImplementation, ExecutionPlan, Set<Channel>, Set<ExecutionStage>) - Constructor for class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler
-
Creates a new instance that enumerates a partial
ExecutionPlan
. - ExecutionTaskFlowCompiler.Activation - Class in org.apache.wayang.core.optimizer.enumeration
-
Propagates a
Channel
to its consumers. - ExecutionTaskFlowCompiler.Activator - Class in org.apache.wayang.core.optimizer.enumeration
-
Takes care of creating
ExecutionTask
s andChannel
s. - executor - Variable in class org.apache.wayang.profiler.java.OperatorProfiler
- Executor - Interface in org.apache.wayang.core.platform
-
An executor executes
ExecutionOperator
s. - Executor - Interface in org.apache.wayang.spark.monitoring.interfaces
-
The Executor interface represents an executor in a Spark cluster.
- Executor.Factory - Interface in org.apache.wayang.core.platform
-
Factory for
Executor
s. - ExecutorAdded - Class in org.apache.wayang.spark.monitoring.metrics
-
The ExecutorAdded class represents an executor added event in a distributed computing system.
- ExecutorAdded() - Constructor for class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- ExecutorRemoved - Class in org.apache.wayang.spark.monitoring.metrics
-
An event class representing the removal of an executor.
- ExecutorRemoved() - Constructor for class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- ExecutorTemplate - Class in org.apache.wayang.core.platform
-
Implements the
ExecutionResource
handling as defined byExecutor
. - ExecutorTemplate(CrossPlatformExecutor) - Constructor for class org.apache.wayang.core.platform.ExecutorTemplate
-
Creates a new instance.
- executorTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the time at which this executor started.
- executorTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- executorTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- executorTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- ExecutorUpdated - Class in org.apache.wayang.spark.monitoring.metrics
-
An implementation of the Executor interface that represents an updated executor.
- ExecutorUpdated() - Constructor for class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- exit(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- exitBinaryOperation(MathExParser.BinaryOperationContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Exit a parse tree produced by the
binaryOperation
labeled alternative inMathExParser.expression()
. - exitBinaryOperation(MathExParser.BinaryOperationContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Exit a parse tree produced by the
binaryOperation
labeled alternative inMathExParser.expression()
. - exitConstant(MathExParser.ConstantContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Exit a parse tree produced by the
constant
labeled alternative inMathExParser.expression()
. - exitConstant(MathExParser.ConstantContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Exit a parse tree produced by the
constant
labeled alternative inMathExParser.expression()
. - exitEveryRule(ParserRuleContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
- exitFunction(MathExParser.FunctionContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Exit a parse tree produced by the
function
labeled alternative inMathExParser.expression()
. - exitFunction(MathExParser.FunctionContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Exit a parse tree produced by the
function
labeled alternative inMathExParser.expression()
. - exitParensExpression(MathExParser.ParensExpressionContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Exit a parse tree produced by the
parensExpression
labeled alternative inMathExParser.expression()
. - exitParensExpression(MathExParser.ParensExpressionContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Exit a parse tree produced by the
parensExpression
labeled alternative inMathExParser.expression()
. - exitRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- exitRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.ConstantContext
- exitRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- exitRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.ParensExpressionContext
- exitRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.UnaryOperationContext
- exitRule(ParseTreeListener) - Method in class org.apache.wayang.core.mathex.MathExParser.VariableContext
- exitUnaryOperation(MathExParser.UnaryOperationContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Exit a parse tree produced by the
unaryOperation
labeled alternative inMathExParser.expression()
. - exitUnaryOperation(MathExParser.UnaryOperationContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Exit a parse tree produced by the
unaryOperation
labeled alternative inMathExParser.expression()
. - exitVariable(MathExParser.VariableContext) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
-
Exit a parse tree produced by the
variable
labeled alternative inMathExParser.expression()
. - exitVariable(MathExParser.VariableContext) - Method in interface org.apache.wayang.core.mathex.MathExListener
-
Exit a parse tree produced by the
variable
labeled alternative inMathExParser.expression()
. - expand(ExecutionPlan) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
The given instance should build upon the open
Channel
s of this instance. - expectationValueComparator() - Static method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
-
Creates a
Comparator
based on the mean of instances. - EXPECTED_ESTIMATE_DEVIATION - Static variable in class org.apache.wayang.basic.operators.AmazonS3Source.CardinalityEstimator
-
We expect selectivities to be correct within a factor of 0.05.
- EXPECTED_ESTIMATE_DEVIATION - Static variable in class org.apache.wayang.basic.operators.AzureBlobStorageSource.CardinalityEstimator
-
We expect selectivities to be correct within a factor of 0.05.
- EXPECTED_ESTIMATE_DEVIATION - Static variable in class org.apache.wayang.basic.operators.GoogleCloudStorageSource.CardinalityEstimator
-
We expect selectivities to be correct within a factor of 0.05.
- EXPECTED_ESTIMATE_DEVIATION - Static variable in class org.apache.wayang.basic.operators.KafkaTopicSource.CardinalityEstimator
- EXPECTED_ESTIMATE_DEVIATION - Static variable in class org.apache.wayang.basic.operators.ObjectFileSource.CardinalityEstimator
-
We expect selectivities to be correct within a factor of 0.05.
- EXPECTED_ESTIMATE_DEVIATION - Static variable in class org.apache.wayang.basic.operators.TextFileSource.CardinalityEstimator
-
We expect selectivities to be correct within a factor of 0.05.
- Experiment - Class in org.apache.wayang.commons.util.profiledb.model
-
An experiment comprises
Measurement
s from one specificSubject
execution. - Experiment(String, Subject, long, String...) - Constructor for class org.apache.wayang.commons.util.profiledb.model.Experiment
-
Create a new instance.
- Experiment(String, Subject, String...) - Constructor for class org.apache.wayang.commons.util.profiledb.model.Experiment
-
Create a new instance that is starting right now.
- explain(WayangPlan, boolean, String...) - Method in class org.apache.wayang.core.api.WayangContext
- explain(WayangPlan, String...) - Method in class org.apache.wayang.core.api.WayangContext
- ExplainTreeNode - Class in org.apache.wayang.core.util
- ExplainTreeNode() - Constructor for class org.apache.wayang.core.util.ExplainTreeNode
- ExplainUtils - Class in org.apache.wayang.core.util
- ExplainUtils() - Constructor for class org.apache.wayang.core.util.ExplainUtils
- exPlanUrl - Variable in class org.apache.wayang.core.monitor.Monitor
- ExplicitCollectionProvider<Value> - Class in org.apache.wayang.core.api.configuration
-
CollectionProvider
implementation based on a blacklist and a whitelist. - ExplicitCollectionProvider(Configuration) - Constructor for class org.apache.wayang.core.api.configuration.ExplicitCollectionProvider
- ExplicitCollectionProvider(Configuration, CollectionProvider<Value>) - Constructor for class org.apache.wayang.core.api.configuration.ExplicitCollectionProvider
- expression() - Method in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- expression() - Method in class org.apache.wayang.core.mathex.MathExParser
- expression() - Method in class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- expression() - Method in class org.apache.wayang.core.mathex.MathExParser.ParensExpressionContext
- expression() - Method in class org.apache.wayang.core.mathex.MathExParser.UnaryOperationContext
- expression(int) - Method in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- expression(int) - Method in class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- Expression - Interface in org.apache.wayang.core.util.mathex
-
A mathematical expression that can be evaluated.
- ExpressionBuilder - Class in org.apache.wayang.core.util.mathex
-
This utility builds
Expression
s from an inputString
. - ExpressionBuilder() - Constructor for class org.apache.wayang.core.util.mathex.ExpressionBuilder
- ExpressionContext() - Constructor for class org.apache.wayang.core.mathex.MathExParser.ExpressionContext
- ExpressionContext(ParserRuleContext, int) - Constructor for class org.apache.wayang.core.mathex.MathExParser.ExpressionContext
- ExtendedBinaryOperatorAdapter<Type> - Class in org.apache.wayang.spark.compiler
-
Implements a
Function2
that callsExtendedFunction.open(ExecutionContext)
of its implementation before delegating the very firstFunction2.call(Object, Object)
. - ExtendedBinaryOperatorAdapter(FunctionDescriptor.ExtendedSerializableBinaryOperator<Type>, SparkExecutionContext) - Constructor for class org.apache.wayang.spark.compiler.ExtendedBinaryOperatorAdapter
- ExtendedFlatMapFunctionAdapter<InputType,
OutputType> - Class in org.apache.wayang.spark.compiler -
Implements a
FlatMapFunction
that callsExtendedFunction.open(ExecutionContext)
of its implementation before delegating the very firstFunction.call(Object)
. - ExtendedFlatMapFunctionAdapter(FunctionDescriptor.ExtendedSerializableFunction, SparkExecutionContext) - Constructor for class org.apache.wayang.spark.compiler.ExtendedFlatMapFunctionAdapter
- ExtendedFunction<InputType,
OutputType> - Class in org.apache.wayang.spark.compiler -
Implements a
Function
that callsExtendedFunction.open(ExecutionContext)
of its implementation before delegating the very firstFunction.call(Object)
. - ExtendedFunction - Interface in org.apache.wayang.core.function
-
Used to enrich regular functions with additional life-cycle methods of
Operator
s. - ExtendedFunction(T, SparkExecutionContext) - Constructor for class org.apache.wayang.spark.compiler.ExtendedFunction
- ExtendedMapFunctionAdapter<InputType,
OutputType> - Class in org.apache.wayang.spark.compiler -
Implements a
Function
that callsExtendedFunction.open(ExecutionContext)
of its implementation before delegating the very firstFunction.call(Object)
. - ExtendedMapFunctionAdapter(FunctionDescriptor.ExtendedSerializableFunction<InputType, OutputType>, SparkExecutionContext) - Constructor for class org.apache.wayang.spark.compiler.ExtendedMapFunctionAdapter
- ExtendedMapPartitionsFunctionAdapter<InputType,
OutputType> - Class in org.apache.wayang.spark.compiler -
Wraps a
Function
as aFlatMapFunction
. - ExtendedMapPartitionsFunctionAdapter(FunctionDescriptor.ExtendedSerializableFunction<Iterable<InputType>, Iterable<OutputType>>, SparkExecutionContext) - Constructor for class org.apache.wayang.spark.compiler.ExtendedMapPartitionsFunctionAdapter
- ExtendedPredicateAdapater<Type> - Class in org.apache.wayang.spark.compiler
-
Implements a
Function
that callsExtendedFunction.open(ExecutionContext)
of its implementation before delegating the very firstFunction.call(Object)
. - ExtendedPredicateAdapater(FunctionDescriptor.ExtendedSerializablePredicate<Type>, SparkExecutionContext) - Constructor for class org.apache.wayang.spark.compiler.ExtendedPredicateAdapater
- extractData<TypeXPivot extends Comparable<TypeXPivot>,
TypeXRef extends Comparable<TypeXRef>, Input> - Class in org.apache.wayang.iejoin.operators.java_helpers -
Created by khayyzy on 5/28/16.
- extractData<TypeXPivot extends Comparable<TypeXPivot>,
TypeXRef extends Comparable<TypeXRef>, Input> - Class in org.apache.wayang.iejoin.operators.spark_helpers -
Created by khayyzy on 5/28/16.
- extractData(Function<Input, TypeXPivot>, Function<Input, TypeXRef>) - Constructor for class org.apache.wayang.iejoin.operators.java_helpers.extractData
- extractData(Function<Input, TypeXPivot>, Function<Input, TypeXRef>) - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.extractData
F
- Factory() - Constructor for class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost.Factory
- FACTORY - Static variable in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
- FAILED - Enum constant in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
- fakeJavaExecutor() - Static method in class org.apache.wayang.profiler.util.ProfilingUtils
-
Provides a
JavaExecutor
. - fakeJob(String...) - Static method in class org.apache.wayang.profiler.util.ProfilingUtils
-
Provides a
Job
. - fakeSparkExecutor(String...) - Static method in class org.apache.wayang.profiler.util.ProfilingUtils
-
Provides a
SparkExecutor
. - FALLBACK_ESTIMATE - Variable in class org.apache.wayang.basic.operators.AmazonS3Source.CardinalityEstimator
- FALLBACK_ESTIMATE - Variable in class org.apache.wayang.basic.operators.AzureBlobStorageSource.CardinalityEstimator
- FALLBACK_ESTIMATE - Variable in class org.apache.wayang.basic.operators.GoogleCloudStorageSource.CardinalityEstimator
- FALLBACK_ESTIMATE - Variable in class org.apache.wayang.basic.operators.KafkaTopicSource.CardinalityEstimator
- FALLBACK_ESTIMATE - Variable in class org.apache.wayang.basic.operators.ObjectFileSource.CardinalityEstimator
- FALLBACK_ESTIMATE - Variable in class org.apache.wayang.basic.operators.ParquetSource.CardinalityEstimator
- FALLBACK_ESTIMATE - Variable in class org.apache.wayang.basic.operators.TextFileSource.CardinalityEstimator
- FallbackCardinalityEstimator - Class in org.apache.wayang.core.optimizer.cardinality
-
Assumes with a confidence of 50% that the output cardinality will be somewhere between 1 and the product of all 10*input estimates.
- FallbackCardinalityEstimator() - Constructor for class org.apache.wayang.core.optimizer.cardinality.FallbackCardinalityEstimator
- fanOut() - Static method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- FEATURES - Enum constant in enum class org.apache.wayang.basic.model.op.Input.Type
- FEATURES - Static variable in class org.apache.wayang.spark.operators.ml.Attr
- fee - Variable in class org.apache.wayang.flink.execution.FlinkExecutor
-
The
ExecutionEnvironment
to be used by this instance. - field0 - Variable in class org.apache.wayang.basic.data.Tuple2
- field0 - Variable in class org.apache.wayang.basic.data.Tuple5
- field0 - Variable in class org.apache.wayang.core.util.Tuple
- field1 - Variable in class org.apache.wayang.basic.data.Tuple2
- field1 - Variable in class org.apache.wayang.basic.data.Tuple5
- field1 - Variable in class org.apache.wayang.core.util.Tuple
- field2 - Variable in class org.apache.wayang.basic.data.Tuple5
- field3 - Variable in class org.apache.wayang.basic.data.Tuple5
- field4 - Variable in class org.apache.wayang.basic.data.Tuple5
- FILE_PARAMETER_KEY - Static variable in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
-
The key under which the name of the target path is stored in the configuration.
- FileChannel - Class in org.apache.wayang.basic.channels
-
Represents a
Channel
that is realized via a file/set of files. - FileChannel(FileChannel.Descriptor) - Constructor for class org.apache.wayang.basic.channels.FileChannel
- FileChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.basic.channels.FileChannel
- FileChannel.Descriptor - Class in org.apache.wayang.basic.channels
-
ChannelDescriptor
forFileChannel
s. - FileChannel.Instance - Class in org.apache.wayang.basic.channels
-
ChannelInstance
implementation forFileChannel
s. - FileChannels - Class in org.apache.wayang.spark.channels
-
Utilities for
FileChannel
s. - FileChannels() - Constructor for class org.apache.wayang.spark.channels.FileChannels
- FileMonitor - Class in org.apache.wayang.core.monitor
- FileMonitor() - Constructor for class org.apache.wayang.core.monitor.FileMonitor
- FileStorage - Class in org.apache.wayang.commons.util.profiledb.storage
- FileStorage(URI) - Constructor for class org.apache.wayang.commons.util.profiledb.storage.FileStorage
-
Assigns File where
Experiment
s will be written regarding to given URI - FileSystem - Interface in org.apache.wayang.core.util.fs
-
Abstraction for accessing a file system.
- FileSystems - Class in org.apache.wayang.core.util.fs
-
Tool to work with
FileSystem
s. - FileUtils - Class in org.apache.wayang.core.util.fs
- FileUtils() - Constructor for class org.apache.wayang.core.util.fs.FileUtils
- filter(InputType) - Method in class org.apache.wayang.flink.compiler.criterion.DummyFilter
- filter(Tuple2<Tuple2<Long, Double>, Tuple2<Long, Double>>) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator.EpsilonFilter
- filter(T) - Method in class org.apache.wayang.flink.compiler.criterion.WayangFilterCriterion
- FilterMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
FilterOperator
toFlinkFilterOperator
. - FilterMapping - Class in org.apache.wayang.genericjdbc.mapping
-
Mapping from
FilterOperator
toGenericJdbcFilterOperator
. - FilterMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
FilterOperator
toJavaFilterOperator
. - FilterMapping - Class in org.apache.wayang.postgres.mapping
-
Mapping from
FilterOperator
toPostgresFilterOperator
. - FilterMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
FilterOperator
toSparkFilterOperator
. - FilterMapping - Class in org.apache.wayang.sqlite3.mapping
-
Mapping from
FilterOperator
toSqlite3FilterOperator
. - FilterMapping() - Constructor for class org.apache.wayang.flink.mapping.FilterMapping
- FilterMapping() - Constructor for class org.apache.wayang.genericjdbc.mapping.FilterMapping
- FilterMapping() - Constructor for class org.apache.wayang.java.mapping.FilterMapping
- FilterMapping() - Constructor for class org.apache.wayang.postgres.mapping.FilterMapping
- FilterMapping() - Constructor for class org.apache.wayang.spark.mapping.FilterMapping
- FilterMapping() - Constructor for class org.apache.wayang.sqlite3.mapping.FilterMapping
- FilterOperator<Type> - Class in org.apache.wayang.basic.operators
-
This operator returns a new dataset after filtering by applying predicateDescriptor.
- FilterOperator(FilterOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.FilterOperator
-
Copies an instance (exclusive of broadcasts).
- FilterOperator(FunctionDescriptor.SerializablePredicate<Type>, Class<Type>) - Constructor for class org.apache.wayang.basic.operators.FilterOperator
-
Creates a new instance.
- FilterOperator(PredicateDescriptor<Type>) - Constructor for class org.apache.wayang.basic.operators.FilterOperator
-
Creates a new instance.
- FilterOperator(PredicateDescriptor<Type>, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.FilterOperator
-
Creates a new instance.
- FilterOperator(DataSetType<Type>, FunctionDescriptor.SerializablePredicate<Type>) - Constructor for class org.apache.wayang.basic.operators.FilterOperator
-
Creates a new instance.
- FilterPredicateImpl - Class in org.apache.wayang.api.sql.calcite.converter.functions
- FilterPredicateImpl(RexNode) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.FilterPredicateImpl
- filterUnwantedBlocks<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>> - Class in org.apache.wayang.iejoin.operators.spark_helpers -
Created by khayyzy on 5/28/16.
- filterUnwantedBlocks(IEJoinMasterOperator.JoinCondition, boolean) - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.filterUnwantedBlocks
- FINAL_OUTPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.DoWhileOperator
- FINAL_OUTPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.LoopOperator
- FINAL_OUTPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.RepeatOperator
- finalise() - Method in class org.apache.wayang.ml4all.abstraction.api.LogicalOperator
- finalise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapper
- finalise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapperWithModel
- findActualInputPaths(String) - Static method in class org.apache.wayang.core.util.fs.FileSystems
-
Systems such as Spark do not produce a single output file often times.
- findActualSingleInputPath(String) - Static method in class org.apache.wayang.core.util.fs.FileSystems
-
As
FileSystems.findActualInputPaths(String)
but requires the presence of only a single input file. - findMinimumCostJunction(OutputSlot<?>, Collection<Channel>, List<InputSlot<?>>, OptimizationContext) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph
-
Finds the minimum tree
Junction
(w.r.t. - findMinimumCostJunction(OutputSlot<?>, List<InputSlot<?>>, OptimizationContext, boolean) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph
-
Finds the minimum tree
Junction
(w.r.t. - findMinMaxRank() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- findTempDir() - Static method in class org.apache.wayang.core.util.fs.LocalFileSystem
-
Retrieves a directory that can be used for temporary files.
- findWayangPlanOutputSlotFor(Channel) - Static method in class org.apache.wayang.core.optimizer.OptimizationUtils
- FINISHED - Enum constant in enum class org.apache.wayang.core.plan.wayangplan.LoopHeadOperator.State
-
The
LoopHeadOperator
has been executed ultimately. - FINISHED - Enum constant in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
- fire() - Method in class org.apache.wayang.java.operators.JavaObjectFileSink.StreamChunker
-
Apply the specified
JavaObjectFileSink.StreamChunker.action
to the current chunk and prepare for a new chunk. - FIRST_EPOCH - Static variable in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Each operator is associated with an epoch, which is a logical timestamp for the operator's creation.
- fitIntercept - Variable in class org.apache.wayang.basic.operators.LinearRegressionOperator
- fitIntercept - Variable in class org.apache.wayang.basic.operators.LogisticRegressionOperator
- fitnessComparator - Static variable in class org.apache.wayang.profiler.log.Individual
-
Orders
Individual
s by their fitness descendingly. - FixBreakpoint - Class in org.apache.wayang.core.platform
-
Describes when to interrupt the execution of an
ExecutionPlan
. - FixBreakpoint() - Constructor for class org.apache.wayang.core.platform.FixBreakpoint
- FixedSizeCardinalityEstimator - Class in org.apache.wayang.core.optimizer.cardinality
-
CardinalityEstimator
implementation forOperator
s with a fix-sized output. - FixedSizeCardinalityEstimator(long) - Constructor for class org.apache.wayang.core.optimizer.cardinality.FixedSizeCardinalityEstimator
- FixedSizeCardinalityEstimator(long, boolean) - Constructor for class org.apache.wayang.core.optimizer.cardinality.FixedSizeCardinalityEstimator
- flatMap(Tuple2<Tuple2<Long, Double>, Tuple2<Long, Long[]>>, Collector<Tuple2<Long, Double>>) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator.JoinVertexWithEdgesMatch
- FlatMapDescriptor<Input,
Output> - Class in org.apache.wayang.core.function -
This descriptor pertains to functions that consume a single data unit and output a group of data units.
- FlatMapDescriptor(FunctionDescriptor.SerializableFunction<Input, Iterable<Output>>, Class<Input>, Class<Output>) - Constructor for class org.apache.wayang.core.function.FlatMapDescriptor
- FlatMapDescriptor(FunctionDescriptor.SerializableFunction<Input, Iterable<Output>>, Class<Input>, Class<Output>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.FlatMapDescriptor
- FlatMapDescriptor(FunctionDescriptor.SerializableFunction<Input, Iterable<Output>>, Class<Input>, Class<Output>, ProbabilisticDoubleInterval) - Constructor for class org.apache.wayang.core.function.FlatMapDescriptor
- FlatMapDescriptor(FunctionDescriptor.SerializableFunction<Input, Iterable<Output>>, Class<Input>, Class<Output>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.FlatMapDescriptor
- FlatMapDescriptor(FunctionDescriptor.SerializableFunction<Input, Iterable<Output>>, BasicDataUnitType<Input>, BasicDataUnitType<Output>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.FlatMapDescriptor
- FlatMapFunctionAdapter<InputType,
OutputType> - Class in org.apache.wayang.spark.compiler -
Wraps a
Function
as aFlatMapFunction
. - FlatMapFunctionAdapter(Function<InputType, Iterable<OutputType>>) - Constructor for class org.apache.wayang.spark.compiler.FlatMapFunctionAdapter
- FlatMapMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
FlatMapOperator
toFlinkFlatMapOperator
. - FlatMapMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
FlatMapOperator
toJavaFlatMapOperator
. - FlatMapMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
FlatMapOperator
toSparkFlatMapOperator
. - FlatMapMapping() - Constructor for class org.apache.wayang.flink.mapping.FlatMapMapping
- FlatMapMapping() - Constructor for class org.apache.wayang.java.mapping.FlatMapMapping
- FlatMapMapping() - Constructor for class org.apache.wayang.spark.mapping.FlatMapMapping
- FlatMapOperator<InputType,
OutputType> - Class in org.apache.wayang.basic.operators -
A flatmap operator represents semantics as they are known from frameworks, such as Spark and Flink.
- FlatMapOperator(FlatMapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.basic.operators.FlatMapOperator
-
Copies an instance (exclusive of broadcasts).
- FlatMapOperator(FlatMapDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.basic.operators.FlatMapOperator
-
Creates a new instance.
- FlatMapOperator(FlatMapDescriptor<InputType, OutputType>, DataSetType<InputType>, DataSetType<OutputType>) - Constructor for class org.apache.wayang.basic.operators.FlatMapOperator
-
Creates a new instance.
- FlatMapOperator(FunctionDescriptor.SerializableFunction<InputType, Iterable<OutputType>>, Class<InputType>, Class<OutputType>) - Constructor for class org.apache.wayang.basic.operators.FlatMapOperator
-
Creates a new instance.
- Flink - Class in org.apache.wayang.flink
-
Register for relevant components of this module.
- Flink() - Constructor for class org.apache.wayang.flink.Flink
- FlinkBasicPlugin - Class in org.apache.wayang.flink.plugin
- FlinkBasicPlugin() - Constructor for class org.apache.wayang.flink.plugin.FlinkBasicPlugin
- FlinkCartesianOperator<InputType0,
InputType1> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
CartesianOperator
. - FlinkCartesianOperator(CartesianOperator<InputType0, InputType1>) - Constructor for class org.apache.wayang.flink.operators.FlinkCartesianOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkCartesianOperator(DataSetType<InputType0>, DataSetType<InputType1>) - Constructor for class org.apache.wayang.flink.operators.FlinkCartesianOperator
-
Creates a new instance.
- FlinkCoGroupFunction<InputType0,
InputType1, OutputType> - Class in org.apache.wayang.flink.compiler -
Wrapper of of Flink for use in Wayang
- FlinkCoGroupFunction() - Constructor for class org.apache.wayang.flink.compiler.FlinkCoGroupFunction
- FlinkCoGroupOperator<InputType0,
InputType1, TypeKey> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
CoGroupOperator
. - FlinkCoGroupOperator(CoGroupOperator<InputType0, InputType1, TypeKey>) - Constructor for class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- FlinkCoGroupOperator(FunctionDescriptor.SerializableFunction<InputType0, TypeKey>, FunctionDescriptor.SerializableFunction<InputType1, TypeKey>, Class<InputType0>, Class<InputType1>, Class<TypeKey>) - Constructor for class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- FlinkCoGroupOperator(TransformationDescriptor<InputType0, TypeKey>, TransformationDescriptor<InputType1, TypeKey>) - Constructor for class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- FlinkCoGroupOperator(TransformationDescriptor<InputType0, TypeKey>, TransformationDescriptor<InputType1, TypeKey>, DataSetType<InputType0>, DataSetType<InputType1>) - Constructor for class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- FlinkCollectionSink<Type> - Class in org.apache.wayang.flink.operators
-
Converts
DataSetChannel
into aCollectionChannel
- FlinkCollectionSink(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkCollectionSink
- FlinkCollectionSource<Type> - Class in org.apache.wayang.flink.operators
-
This is execution operator implements the
CollectionSource
. - FlinkCollectionSource(Collection<Type>, DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkCollectionSource
- FlinkCollectionSource(CollectionSource<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkCollectionSource
-
Copies an instance (exclusive of broadcasts).
- FlinkCollectionSource(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkCollectionSource
- FlinkContextReference - Class in org.apache.wayang.flink.execution
-
Wraps and manages a Flink
ExecutionEnvironment
to avoid steady re-creation. - FlinkContextReference(CrossPlatformExecutor, ExecutionEnvironment, int) - Constructor for class org.apache.wayang.flink.execution.FlinkContextReference
-
Creates a new instance.
- FlinkConversionPlugin - Class in org.apache.wayang.flink.plugin
- FlinkConversionPlugin() - Constructor for class org.apache.wayang.flink.plugin.FlinkConversionPlugin
- FlinkCountOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
CountOperator
. - FlinkCountOperator(CountOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkCountOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkCountOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkCountOperator
-
Creates a new instance.
- FlinkDistinctOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
DistinctOperator
. - FlinkDistinctOperator(DistinctOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkDistinctOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkDistinctOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkDistinctOperator
-
Creates a new instance.
- FlinkDoWhileOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
DoWhileOperator
. - FlinkDoWhileOperator(DoWhileOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.flink.operators.FlinkDoWhileOperator
-
Creates a new instance.
- FlinkDoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.flink.operators.FlinkDoWhileOperator
-
Creates a new instance.
- FlinkDoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- FlinkExecutionContext - Class in org.apache.wayang.flink.execution
-
ExecutionContext
implementation for theFlinkPlatform
. - FlinkExecutionContext(FlinkExecutionOperator, ChannelInstance[], int) - Constructor for class org.apache.wayang.flink.execution.FlinkExecutionContext
- FlinkExecutionOperator - Interface in org.apache.wayang.flink.operators
-
Execution operator for the Flink platform.
- FlinkExecutor - Class in org.apache.wayang.flink.execution
-
Executor
implementation for theFlinkPlatform
. - FlinkExecutor(FlinkPlatform, Job) - Constructor for class org.apache.wayang.flink.execution.FlinkExecutor
- FlinkFilterOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
FilterOperator
. - FlinkFilterOperator(FilterOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkFilterOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkFilterOperator(DataSetType<Type>, PredicateDescriptor<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkFilterOperator
-
Creates a new instance.
- FlinkFlatMapOperator<InputType,
OutputType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
FlatMapOperator
. - FlinkFlatMapOperator() - Constructor for class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- FlinkFlatMapOperator(FlatMapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkFlatMapOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkFlatMapOperator(DataSetType<InputType>, DataSetType<OutputType>, FlatMapDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkFlatMapOperator
-
Creates a new instance.
- FlinkGlobalMaterializedGroupOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
GlobalMaterializedGroupOperator
. - FlinkGlobalMaterializedGroupOperator(Class<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- FlinkGlobalMaterializedGroupOperator(GlobalMaterializedGroupOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkGlobalMaterializedGroupOperator(DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- FlinkGlobalReduceOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
GlobalReduceOperator
. - FlinkGlobalReduceOperator(GlobalReduceOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkGlobalReduceOperator(DataSetType<Type>, ReduceDescriptor<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
-
Creates a new instance.
- FlinkGraphPlugin - Class in org.apache.wayang.flink.plugin
- FlinkGraphPlugin() - Constructor for class org.apache.wayang.flink.plugin.FlinkGraphPlugin
- FlinkGroupByOperator<InputType,
KeyType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
GroupByOperator
. - FlinkGroupByOperator(GroupByOperator<InputType, KeyType>) - Constructor for class org.apache.wayang.flink.operators.FlinkGroupByOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkGroupByOperator(TransformationDescriptor<InputType, KeyType>, DataSetType<InputType>, DataSetType<KeyType>) - Constructor for class org.apache.wayang.flink.operators.FlinkGroupByOperator
-
Creates a new instance.
- FlinkIntersectOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
IntersectOperator
. - FlinkIntersectOperator(Class<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkIntersectOperator
- FlinkIntersectOperator(IntersectOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkIntersectOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkIntersectOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkIntersectOperator
- FlinkJoinOperator<InputType0,
InputType1, KeyType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
JoinOperator
. - FlinkJoinOperator(JoinOperator<InputType0, InputType1, KeyType>) - Constructor for class org.apache.wayang.flink.operators.FlinkJoinOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkJoinOperator(DataSetType<InputType0>, DataSetType<InputType1>, TransformationDescriptor<InputType0, KeyType>, TransformationDescriptor<InputType1, KeyType>) - Constructor for class org.apache.wayang.flink.operators.FlinkJoinOperator
-
Creates a new instance.
- FlinkLocalCallbackSink<Type extends Serializable> - Class in org.apache.wayang.flink.operators
-
Implementation of the
LocalCallbackSink
operator for the Flink platform. - FlinkLocalCallbackSink(LocalCallbackSink<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
-
Copies an instance (exclusive of broadcasts).
- FlinkLocalCallbackSink(FunctionDescriptor.SerializableConsumer<Type>, DataSetType) - Constructor for class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
-
Creates a new instance.
- FlinkLoopOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
RepeatOperator
. - FlinkLoopOperator(LoopOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.flink.operators.FlinkLoopOperator
-
Creates a copy of the given
LoopOperator
. - FlinkLoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.flink.operators.FlinkLoopOperator
-
Creates a new instance.
- FlinkLoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.flink.operators.FlinkLoopOperator
- FlinkMapOperator<InputType,
OutputType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
MapOperator
. - FlinkMapOperator(MapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkMapOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkMapOperator(DataSetType<InputType>, DataSetType<OutputType>, TransformationDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkMapOperator
-
Creates a new instance.
- FlinkMapPartitionsOperator<InputType,
OutputType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
MapPartitionsOperator
. - FlinkMapPartitionsOperator(MapPartitionsOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkMapPartitionsOperator(MapPartitionsDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
-
Creates a new instance.
- FlinkMapPartitionsOperator(MapPartitionsDescriptor<InputType, OutputType>, DataSetType<InputType>, DataSetType<OutputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
-
Creates a new instance.
- FlinkMaterializedGroupByOperator<Type,
KeyType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
MaterializedGroupByOperator
. - FlinkMaterializedGroupByOperator(MaterializedGroupByOperator<Type, KeyType>) - Constructor for class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkMaterializedGroupByOperator(TransformationDescriptor<Type, KeyType>, DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- FlinkObjectFileSink<Type> - Class in org.apache.wayang.flink.operators
-
Operator
for theFlinkPlatform
that creates a sequence file. - FlinkObjectFileSink(String, DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkObjectFileSink
- FlinkObjectFileSink(ObjectFileSink<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkObjectFileSink
- FlinkObjectFileSink(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkObjectFileSink
- FlinkObjectFileSource<Type> - Class in org.apache.wayang.flink.operators
-
Operator
for theFlinkPlatform
that creates a sequence file. - FlinkObjectFileSource(String, DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkObjectFileSource
- FlinkObjectFileSource(ObjectFileSource<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkObjectFileSource
- FlinkObjectFileSource(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkObjectFileSource
- FlinkPageRankOperator - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
PageRankOperator
. - FlinkPageRankOperator(Integer) - Constructor for class org.apache.wayang.flink.operators.FlinkPageRankOperator
- FlinkPageRankOperator(PageRankOperator) - Constructor for class org.apache.wayang.flink.operators.FlinkPageRankOperator
- FlinkPageRankOperator.BuildOutgoingEdgeList - Class in org.apache.wayang.flink.operators
-
A reduce function that takes a sequence of edges and builds the adjacency list for the vertex where the edges originate.
- FlinkPageRankOperator.Dampener - Class in org.apache.wayang.flink.operators
-
The function that applies the page rank dampening formula.
- FlinkPageRankOperator.EpsilonFilter - Class in org.apache.wayang.flink.operators
-
Filter that filters vertices where the rank difference is below a threshold.
- FlinkPageRankOperator.JoinVertexWithEdgesMatch - Class in org.apache.wayang.flink.operators
-
Join function that distributes a fraction of a vertex's rank to all neighbors.
- FlinkPageRankOperator.RankAssigner - Class in org.apache.wayang.flink.operators
-
A map function that assigns an initial rank to all pages.
- FlinkPlatform - Class in org.apache.wayang.flink.platform
-
Platform
for Apache Flink. - FlinkReduceByOperator<InputType,
KeyType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
ReduceByOperator
. - FlinkReduceByOperator(ReduceByOperator<InputType, KeyType>) - Constructor for class org.apache.wayang.flink.operators.FlinkReduceByOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkReduceByOperator(DataSetType<InputType>, TransformationDescriptor<InputType, KeyType>, ReduceDescriptor<InputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkReduceByOperator
-
Creates a new instance.
- FlinkRepeatExpandedOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
RepeatOperator
. - FlinkRepeatExpandedOperator(int, DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
-
Creates a new instance.
- FlinkRepeatExpandedOperator(RepeatOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
- FlinkRepeatOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
RepeatOperator
. - FlinkRepeatOperator(int, DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkRepeatOperator
-
Creates a new instance.
- FlinkRepeatOperator(RepeatOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkRepeatOperator
- FlinkSampleOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
SampleOperator
. - FlinkSampleOperator(SampleOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkSampleOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkSampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, FunctionDescriptor.SerializableLongUnaryOperator) - Constructor for class org.apache.wayang.flink.operators.FlinkSampleOperator
-
Creates a new instance.
- FlinkSortOperator<InputType,
KeyType> - Class in org.apache.wayang.flink.operators -
Flink implementation of the
SortOperator
. - FlinkSortOperator(SortOperator<InputType, KeyType>) - Constructor for class org.apache.wayang.flink.operators.FlinkSortOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkSortOperator(TransformationDescriptor<InputType, KeyType>, DataSetType<InputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkSortOperator
-
Creates a new instance.
- FlinkTextFileSink<Type> - Class in org.apache.wayang.flink.operators
-
Implementation of the
TextFileSink
operator for the Flink platform. - FlinkTextFileSink(String, TransformationDescriptor<Type, String>) - Constructor for class org.apache.wayang.flink.operators.FlinkTextFileSink
- FlinkTextFileSink(TextFileSink<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkTextFileSink
- FlinkTextFileSource - Class in org.apache.wayang.flink.operators
-
Provides a
Collection
to a Flink job. - FlinkTextFileSource(String) - Constructor for class org.apache.wayang.flink.operators.FlinkTextFileSource
- FlinkTextFileSource(String, String) - Constructor for class org.apache.wayang.flink.operators.FlinkTextFileSource
- FlinkTextFileSource(TextFileSource) - Constructor for class org.apache.wayang.flink.operators.FlinkTextFileSource
-
Copies an instance (exclusive of broadcasts).
- FlinkTsvFileSink<Type extends Tuple2<?,
?>> - Class in org.apache.wayang.flink.operators -
Created by bertty on 31-10-17.
- FlinkTsvFileSink(String, DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkTsvFileSink
- FlinkTsvFileSink(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkTsvFileSink
- FlinkUnionAllOperator<Type> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
UnionAllOperator
. - FlinkUnionAllOperator(UnionAllOperator<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkUnionAllOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkUnionAllOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.flink.operators.FlinkUnionAllOperator
-
Creates a new instance.
- FlinkZipWithIdOperator<InputType> - Class in org.apache.wayang.flink.operators
-
Flink implementation of the
MapOperator
. - FlinkZipWithIdOperator(Class<InputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
-
Creates a new instance.
- FlinkZipWithIdOperator(ZipWithIdOperator<InputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
-
Copies an instance (exclusive of broadcasts).
- FlinkZipWithIdOperator(DataSetType<InputType>) - Constructor for class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
-
Creates a new instance.
- flip(int, int) - Method in class org.apache.wayang.core.util.Bitmask
-
Flips all bits in the given range
- FLOAT32 - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
- FLOAT64 - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
- followingInputsDownstreamIf(Predicate<InputSlot<?>>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- followingInputsIf(Predicate<InputSlot<?>>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- followingOutputsIf(Predicate<OutputSlot<?>>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- followInput(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- followInput(InputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Enter the encased plan by following an
inputSlot
of the encasingCompositeOperator
. - followInput(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- followInputs(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Override to control the traversal behavior.
- followInputUnchecked(InputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
- followOutput(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- followOutput(OutputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Exit the encased plan by following an
outputSlot
of an encased, terminalOperator
. - followOutput(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- followOutputRecursively(OutputSlot<T>) - Static method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
-
Recursively follow the given
outputSlot
. - followOutputs(Stream<OutputSlot<?>>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Override to control the traversal behavior.
- followUp(Operator, OutputSlot<?>, Payload, Return) - Method in class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
- fork() - Method in class org.apache.wayang.core.api.Configuration
-
Creates a child instance.
- fork(String) - Method in class org.apache.wayang.core.api.Configuration
-
Creates a child instance.
- formatData(String, Integer) - Static method in class org.apache.wayang.applications.Util
- formatDuration(long) - Static method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
-
Formats the given milliseconds as
h:MM:ss.mmm
. - formatDuration(long) - Static method in class org.apache.wayang.core.util.Formats
-
Formats the given milliseconds as
h:MM:ss.mmm
. - formatDuration(long, boolean) - Static method in class org.apache.wayang.core.util.Formats
-
Formats the given milliseconds as
h:MM:ss.mmm (millis ms)
. - formatLarge(long) - Static method in class org.apache.wayang.core.util.Formats
-
Formats a large number by replacing less significant digits with G, M, or K.
- formatPercentage(double) - Static method in class org.apache.wayang.core.util.Formats
-
Formats a value in
[0, 1]
as a percentage with 2 decimal places. - Formats - Class in org.apache.wayang.core.util
-
Formats different general purpose objects.
- Formats() - Constructor for class org.apache.wayang.core.util.Formats
- formattingDescriptor - Variable in class org.apache.wayang.basic.operators.KafkaTopicSink
- formattingDescriptor - Variable in class org.apache.wayang.basic.operators.TextFileSink
- forward(ChannelInstance, ChannelInstance) - Static method in interface org.apache.wayang.java.operators.JavaExecutionOperator
-
Utility method to forward a
JavaChannelInstance
to another. - forward(ChannelInstance, ChannelInstance) - Method in class org.apache.wayang.spark.execution.SparkExecutor
-
Utility method to forward a
RddChannel.Instance
to another. - fromJson(WayangJsonObj) - Static method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
-
Parses the given
WayangJsonObj
to create a new instance. - fromJson(WayangJsonObj) - Static method in class org.apache.wayang.core.optimizer.costs.LoadEstimate
- fromJson(WayangJsonObj) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- fromJson(WayangJsonObj) - Static method in class org.apache.wayang.core.util.ExplainTreeNode
- fromJson(WayangJsonObj) - Static method in class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
- fromJson(WayangJsonObj) - Static method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator
- fromList - Variable in class org.apache.wayang.basic.model.op.Op
- fromOperatorPatterns(OperatorPattern, OperatorPattern) - Static method in class org.apache.wayang.core.mapping.SubplanPattern
-
Creates a new instance that matches a graph of operator patterns.
- FullInstrumentationStrategy - Class in org.apache.wayang.core.profiling
-
Instruments only outbound
Channel
s. - FullInstrumentationStrategy() - Constructor for class org.apache.wayang.core.profiling.FullInstrumentationStrategy
- FunctionalCollectionProvider<Value> - Class in org.apache.wayang.core.api.configuration
-
CollectionProvider
implementation based on a blacklist and a whitelist. - FunctionalCollectionProvider(Function<Configuration, Collection<Value>>, Configuration) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalCollectionProvider
- FunctionalCollectionProvider(Function<Configuration, Collection<Value>>, Configuration, CollectionProvider) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalCollectionProvider
- FunctionalKeyValueProvider<Key,
Value> - Class in org.apache.wayang.core.api.configuration -
Implementation of
KeyValueProvider
that uses aFunction
to provide a value. - FunctionalKeyValueProvider(BiFunction<Key, KeyValueProvider<Key, Value>, Value>, Configuration) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalKeyValueProvider
- FunctionalKeyValueProvider(Function<Key, Value>, Configuration) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalKeyValueProvider
- FunctionalKeyValueProvider(KeyValueProvider<Key, Value>, BiFunction<Key, KeyValueProvider<Key, Value>, Value>) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalKeyValueProvider
- FunctionalKeyValueProvider(KeyValueProvider<Key, Value>, Function<Key, Value>) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalKeyValueProvider
- FunctionalValueProvider<Value> - Class in org.apache.wayang.core.api.configuration
-
Used by
Configuration
s to provide some value. - FunctionalValueProvider(Function<ValueProvider<Value>, Value>, Configuration) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalValueProvider
- FunctionalValueProvider(Function<ValueProvider<Value>, Value>, ValueProvider<Value>) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalValueProvider
- FunctionalValueProvider(Function<ValueProvider<Value>, Value>, Configuration, ValueProvider<Value>) - Constructor for class org.apache.wayang.core.api.configuration.FunctionalValueProvider
- functionCompiler - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- FunctionCompiler - Class in org.apache.wayang.flink.compiler
-
A compiler translates Wayang functions into executable Flink functions.
- FunctionCompiler - Class in org.apache.wayang.java.compiler
-
A compiler translates Wayang functions into executable Java functions.
- FunctionCompiler - Class in org.apache.wayang.jdbc.compiler
-
Compiles
FunctionDescriptor
s to SQL clauses. - FunctionCompiler - Class in org.apache.wayang.spark.compiler
-
A compiler translates Wayang functions into executable Java functions.
- FunctionCompiler() - Constructor for class org.apache.wayang.flink.compiler.FunctionCompiler
- FunctionCompiler() - Constructor for class org.apache.wayang.jdbc.compiler.FunctionCompiler
- FunctionCompiler() - Constructor for class org.apache.wayang.spark.compiler.FunctionCompiler
- FunctionCompiler(Configuration) - Constructor for class org.apache.wayang.java.compiler.FunctionCompiler
- FunctionCompiler.KeyExtractor<T,
K> - Class in org.apache.wayang.spark.compiler -
Spark function for building pair RDDs.
- FunctionCompiler.Reducer<Type> - Class in org.apache.wayang.spark.compiler
-
Spark function for aggregating data quanta.
- FunctionCompiler.WayangSparkFunction - Interface in org.apache.wayang.spark.compiler
-
Describes functions coming from Wayang, designated for Spark.
- FunctionContext(MathExParser.ExpressionContext) - Constructor for class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- functionDescriptor - Variable in class org.apache.wayang.basic.operators.FlatMapOperator
-
Function that this operator applies to the input elements.
- functionDescriptor - Variable in class org.apache.wayang.basic.operators.MapOperator
-
Function that this operator applies to the input elements.
- functionDescriptor - Variable in class org.apache.wayang.basic.operators.MapPartitionsOperator
-
Function that this operator applies to the input elements.
- FunctionDescriptor - Class in org.apache.wayang.core.function
-
A function operates on single data units or collections of those.
- FunctionDescriptor() - Constructor for class org.apache.wayang.core.function.FunctionDescriptor
- FunctionDescriptor(LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.FunctionDescriptor
- FunctionDescriptor.ExtendedSerializableBinaryOperator<Type> - Interface in org.apache.wayang.core.function
-
Extends a
FunctionDescriptor.SerializableBinaryOperator
to anExtendedFunction
. - FunctionDescriptor.ExtendedSerializableConsumer<T> - Interface in org.apache.wayang.core.function
-
Extends a
FunctionDescriptor.SerializableConsumer
to anExtendedFunction
. - FunctionDescriptor.ExtendedSerializableFunction<Input,
Output> - Interface in org.apache.wayang.core.function -
Extends a
FunctionDescriptor.SerializableFunction
to anExtendedFunction
. - FunctionDescriptor.ExtendedSerializablePredicate<T> - Interface in org.apache.wayang.core.function
- FunctionDescriptor.SerializableBiFunction<Input0,
Input1, Output> - Interface in org.apache.wayang.core.function -
Decorates the default
Function
withSerializable
, which is required by some distributed frameworks. - FunctionDescriptor.SerializableBinaryOperator<Type> - Interface in org.apache.wayang.core.function
-
Decorates the default
Function
withSerializable
, which is required by some distributed frameworks. - FunctionDescriptor.SerializableConsumer<T> - Interface in org.apache.wayang.core.function
-
Decorates the default
Consumer
withSerializable
, which is required by some distributed frameworks. - FunctionDescriptor.SerializableFunction<Input,
Output> - Interface in org.apache.wayang.core.function -
Decorates the default
Function
withSerializable
, which is required by some distributed frameworks. - FunctionDescriptor.SerializableIntUnaryOperator - Interface in org.apache.wayang.core.function
- FunctionDescriptor.SerializableLongUnaryOperator - Interface in org.apache.wayang.core.function
- FunctionDescriptor.SerializablePredicate<T> - Interface in org.apache.wayang.core.function
- FunctionDescriptor.SerializableToDoubleBiFunction<T,
U> - Interface in org.apache.wayang.core.function - FunctionDescriptor.SerializableToLongBiFunction<T,
U> - Interface in org.apache.wayang.core.function - FunctionDescriptor.SerializableToLongFunction<T> - Interface in org.apache.wayang.core.function
G
- generalize(Class<? extends T>) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Casts the given
Class
to a more general one. - GenericChannelConversions - Class in org.apache.wayang.genericjdbc.channels
-
Register for the
ChannelConversion
s supported for this platform. - GenericChannelConversions() - Constructor for class org.apache.wayang.genericjdbc.channels.GenericChannelConversions
- GenericJdbc - Class in org.apache.wayang.genericjdbc
-
Register for relevant components of this module.
- GenericJdbc() - Constructor for class org.apache.wayang.genericjdbc.GenericJdbc
- GenericJdbcConversionsPlugin - Class in org.apache.wayang.genericjdbc.plugin
- GenericJdbcConversionsPlugin() - Constructor for class org.apache.wayang.genericjdbc.plugin.GenericJdbcConversionsPlugin
- GenericJdbcExecutionOperator - Interface in org.apache.wayang.genericjdbc.operators
- GenericJdbcExecutor - Class in org.apache.wayang.genericjdbc.execution
-
Executor
implementation for theGenericJdbcPlatform
. - GenericJdbcExecutor(GenericJdbcPlatform, Job) - Constructor for class org.apache.wayang.genericjdbc.execution.GenericJdbcExecutor
- GenericJdbcFilterOperator - Class in org.apache.wayang.genericjdbc.operators
-
GenericJdbc implementation of the
FilterOperator
. - GenericJdbcFilterOperator(FilterOperator<Record>) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericJdbcFilterOperator
-
Copies an instance (exclusive of broadcasts).
- GenericJdbcFilterOperator(PredicateDescriptor<Record>) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericJdbcFilterOperator
-
Creates a new instance.
- GenericJdbcPlatform - Class in org.apache.wayang.genericjdbc.platform
-
Platform
implementation for GenericJdbc. - GenericJdbcPlatform() - Constructor for class org.apache.wayang.genericjdbc.platform.GenericJdbcPlatform
- GenericJdbcPlugin - Class in org.apache.wayang.genericjdbc.plugin
- GenericJdbcPlugin() - Constructor for class org.apache.wayang.genericjdbc.plugin.GenericJdbcPlugin
- GenericJdbcProjectionOperator - Class in org.apache.wayang.genericjdbc.operators
-
GenericJdbc implementation of the
FilterOperator
. - GenericJdbcProjectionOperator(String...) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericJdbcProjectionOperator
- GenericJdbcProjectionOperator(ProjectionDescriptor<Record, Record>) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericJdbcProjectionOperator
- GenericJdbcProjectionOperator(MapOperator<Record, Record>) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericJdbcProjectionOperator
- GenericJdbcTableSource - Class in org.apache.wayang.genericjdbc.operators
- GenericJdbcTableSource(String, String, String...) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericJdbcTableSource
- GenericJdbcTableSource(GenericJdbcTableSource) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericJdbcTableSource
-
Copies an instance (exclusive of broadcasts).
- GenericSqlToStreamOperator - Class in org.apache.wayang.genericjdbc.operators
- GenericSqlToStreamOperator(GenericSqlToStreamOperator) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
- GenericSqlToStreamOperator(GenericJdbcPlatform) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
-
Creates a new instance.
- GenericSqlToStreamOperator(GenericJdbcPlatform, DataSetType<Record>) - Constructor for class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
-
Creates a new instance.
- GeneticOptimizer - Class in org.apache.wayang.profiler.log
-
Implementation of the genetic optimization technique for finding good
LoadProfileEstimator
s. - GeneticOptimizer(OptimizationSpace, Collection<PartialExecution>, Map<String, DynamicLoadProfileEstimator>, Map<Platform, Variable>, Configuration) - Constructor for class org.apache.wayang.profiler.log.GeneticOptimizer
-
Creates a new instance.
- GeneticOptimizerApp - Class in org.apache.wayang.profiler.log
-
This app tries to infer good
LoadProfileEstimator
s forExecutionOperator
s using data from anExecutionLog
. - GeneticOptimizerApp(Configuration) - Constructor for class org.apache.wayang.profiler.log.GeneticOptimizerApp
-
Creates a new instance.
- get() - Method in class org.apache.wayang.flink.compiler.criterion.WayangValue
- get() - Method in class org.apache.wayang.flink.execution.FlinkContextReference
-
Provides the
ExecutionEnvironment
. - get() - Method in class org.apache.wayang.spark.execution.SparkContextReference
-
Provides the
JavaSparkContext
. - get(int) - Method in class org.apache.wayang.core.util.Bitmask
-
Gets the bit at the given index.
- get(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- get(T) - Method in class org.apache.wayang.core.util.Counter
- Get - Class in org.apache.wayang.basic.model.op
- Get(Object) - Constructor for class org.apache.wayang.basic.model.op.Get
- Get(Object, String) - Constructor for class org.apache.wayang.basic.model.op.Get
- Get(Object, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Get
- Get(Object, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Get
- get0Pivot - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- get0Pivot - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- get0Ref - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- get0Ref - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- get1Pivot - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- get1Ref - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- getAccuracyCalculation() - Method in class org.apache.wayang.basic.operators.DLTrainingOperator.Option
- getAccuracyCalculation() - Method in class org.apache.wayang.tensorflow.model.TensorflowModel
- getActivatedGenes() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getActivatedInput() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activation
- getAdjacentEnumerations() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- getAggregate() - Method in class org.apache.wayang.flink.compiler.criterion.WayangAggregator
- getAggregateContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- getAllInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getAllInputs() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getAllOutputs() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getAllOutputs() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getAllTasks() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Collects all
ExecutionTask
s of this instance. - getAlternatives() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- getAny(Iterable<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Return any element from the
iterable
. - getAnyOptional(Iterable<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Return any element from the
iterable
if it exists. - getAppID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Returns the ID of the application.
- getAppID() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- getAppID() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- getATN() - Method in class org.apache.wayang.core.mathex.MathExLexer
- getATN() - Method in class org.apache.wayang.core.mathex.MathExParser
- getAtomicExecutionGroups() - Method in class org.apache.wayang.core.platform.PartialExecution
-
Provide the
AtomicExecutionGroup
s captured by this instance - getAtomicExecutions() - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
- getAtomicExecutions() - Method in class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
-
Retrieve the encapsulated
AtomicExecution
s - getAverageEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- getAverageEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- getBase() - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
- getBase() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getBaseEnumeration() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- getBaseType() - Method in class org.apache.wayang.core.types.DataUnitGroupType
- getBatchSize() - Method in class org.apache.wayang.basic.operators.DLTrainingOperator.Option
- getBetaOne() - Method in class org.apache.wayang.basic.model.optimizer.Adam
- getBetaTwo() - Method in class org.apache.wayang.basic.model.optimizer.Adam
- getBias() - Method in class org.apache.wayang.basic.model.op.nn.Conv
- getBias() - Method in class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- getBias() - Method in class org.apache.wayang.basic.model.op.nn.Linear
- getBlob() - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- getBlobByteSize() - Method in class org.apache.wayang.basic.operators.AmazonS3Source
- getBlobByteSize() - Method in class org.apache.wayang.basic.operators.AzureBlobStorageSource
- getBlobByteSize() - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- getBlobName() - Method in class org.apache.wayang.basic.operators.AmazonS3Source
- getBlobName() - Method in class org.apache.wayang.basic.operators.AzureBlobStorageSource
- getBlobName() - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- getBodyImplementation() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getBooleanProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getBooleanProperty(String, boolean) - Method in class org.apache.wayang.core.api.Configuration
- getBroadcast(String) - Method in interface org.apache.wayang.core.function.ExecutionContext
-
Accesses a broadcast.
- getBroadcast(String) - Method in class org.apache.wayang.flink.execution.FlinkExecutionContext
- getBroadcast(String) - Method in class org.apache.wayang.java.execution.JavaExecutionContext
- getBroadcast(String) - Method in class org.apache.wayang.spark.execution.SparkExecutionContext
- getBroadCastFunction(String) - Method in interface org.apache.wayang.flink.operators.FlinkExecutionOperator
- getBucket() - Method in class org.apache.wayang.basic.operators.AmazonS3Source
- getBucket() - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- getByKey(String) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allModel
- getByteRead() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the number of bytes read by the task.
- getByteRead() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getBytesWrittern() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Returns the number of bytes written by the task.
- getBytesWrittern() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getCache() - Method in class org.apache.wayang.core.api.Job
-
Provides a general-purpose cache.
- getCalciteSchema(Connection) - Static method in class org.apache.wayang.api.sql.calcite.schema.SchemaUtils
- getCallback() - Method in class org.apache.wayang.basic.operators.LocalCallbackSink
- getCallbackDescriptor() - Method in class org.apache.wayang.basic.operators.LocalCallbackSink
- getCapacity() - Method in class org.apache.wayang.core.util.LruCache
- getCardinalityEstimate() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
-
Deprecated.These method does not do anything, anymore.
- getCardinalityEstimate(OptimizationContext) - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getCardinalityEstimator(int) - Method in interface org.apache.wayang.core.plan.wayangplan.ElementaryOperator
-
Retrieve a
CardinalityEstimator
tied specifically to this instance. - getCardinalityEstimator(int) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
-
Retrieve a
CardinalityEstimator
tied specifically to this instance. - getCardinalityEstimator(int) - Method in class org.apache.wayang.genericjdbc.operators.GenericJdbcTableSource
- getCardinalityEstimator(int) - Method in class org.apache.wayang.jdbc.operators.JdbcTableSource
- getCardinalityEstimatorProvider() - Method in class org.apache.wayang.core.api.Configuration
- getCardinalityMeasurements() - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- getCardinalityMeasurements() - Method in interface org.apache.wayang.core.platform.ExecutionState
-
Retrieve previously registered cardinality measurements
- getCardinalityPusher(Configuration) - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getCardinalityPusher(Configuration) - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
Get the
CardinalityPusher
implementation for the intermediate iterations. - getCardinalityPusher(Configuration) - Method in class org.apache.wayang.core.plan.wayangplan.LoopSubplan
- getCardinalityPusher(Configuration) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Provide a
CardinalityPusher
for theOperator
. - getCardinalityPusher(Configuration) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- getCardinalityPusher(Configuration) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- getCardinalityRepository() - Method in class org.apache.wayang.core.api.WayangContext
- getChannel() - Method in class org.apache.wayang.basic.channels.FileChannel.Instance
- getChannel() - Method in interface org.apache.wayang.core.platform.ChannelInstance
- getChannel() - Method in class org.apache.wayang.flink.channels.DataSetChannel.Instance
- getChannel() - Method in class org.apache.wayang.java.channels.CollectionChannel.Instance
- getChannel() - Method in class org.apache.wayang.java.channels.StreamChannel.Instance
- getChannel() - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Instance
- getChannel() - Method in class org.apache.wayang.spark.channels.BroadcastChannel.Instance
- getChannel() - Method in class org.apache.wayang.spark.channels.RddChannel.Instance
- getChannel() - Method in class org.apache.wayang.tensorflow.channels.TensorChannel.Instance
- getChannelClass() - Method in class org.apache.wayang.core.platform.ChannelDescriptor
- getChannelConversionGraph() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getChannelConversionProvider() - Method in class org.apache.wayang.core.api.Configuration
- getChannelConversions() - Method in class org.apache.wayang.basic.plugin.WayangBasic
- getChannelConversions() - Method in class org.apache.wayang.basic.plugin.WayangBasicGraph
- getChannelConversions() - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- getChannelConversions() - Method in interface org.apache.wayang.core.plugin.Plugin
-
Provides the
ChannelConversion
s shipped with this instance. - getChannelConversions() - Method in class org.apache.wayang.flink.plugin.FlinkBasicPlugin
- getChannelConversions() - Method in class org.apache.wayang.flink.plugin.FlinkConversionPlugin
- getChannelConversions() - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcConversionsPlugin
- getChannelConversions() - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcPlugin
- getChannelConversions() - Method in class org.apache.wayang.giraph.plugin.GiraphPlugin
- getChannelConversions() - Method in class org.apache.wayang.java.plugin.JavaBasicPlugin
- getChannelConversions() - Method in class org.apache.wayang.java.plugin.JavaChannelConversionPlugin
- getChannelConversions() - Method in class org.apache.wayang.java.plugin.JavaGraphPlugin
- getChannelConversions() - Method in class org.apache.wayang.postgres.plugin.PostgresConversionsPlugin
- getChannelConversions() - Method in class org.apache.wayang.postgres.plugin.PostgresPlugin
- getChannelConversions() - Method in class org.apache.wayang.spark.plugin.SparkBasicPlugin
- getChannelConversions() - Method in class org.apache.wayang.spark.plugin.SparkConversionPlugin
- getChannelConversions() - Method in class org.apache.wayang.spark.plugin.SparkGraphPlugin
- getChannelConversions() - Method in class org.apache.wayang.spark.plugin.SparkMLPlugin
- getChannelConversions() - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3ConversionPlugin
- getChannelConversions() - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3Plugin
- getChannelConversions() - Method in class org.apache.wayang.tensorflow.plugin.TensorflowConversionPlugin
- getChannelConversions() - Method in class org.apache.wayang.tensorflow.plugin.TensorflowPlugin
- getChannelInstance() - Method in class org.apache.wayang.core.platform.lineage.ChannelLineageNode
-
Retrieve the encapsulated
ChannelInstance
. - getChannelInstance(Channel) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- getChannelInstance(Channel) - Method in interface org.apache.wayang.core.platform.ExecutionState
-
Obtain a previously registered
ChannelInstance
. - getChannelInstance(Channel, boolean) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- getChannelNames() - Method in class org.apache.wayang.core.mathex.MathExLexer
- getChannels() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement
- getChosenAlternative(OperatorAlternative) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Find for a given
OperatorAlternative
, whichOperatorAlternative.Alternative
has been picked by this instance - getClassTag(WayangJsonObj) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Read and load the specified
Class
in aWayangJsonObj
. - getClusterCenters() - Method in interface org.apache.wayang.basic.model.KMeansModel
- getClusterCenters() - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator.Model
- getCoefficients() - Method in interface org.apache.wayang.basic.model.LinearRegressionModel
- getCoefficients() - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator.Model
- getCollations() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableStatistic
- getCollection() - Method in class org.apache.wayang.basic.operators.CollectionSource
- getColumnNames() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- getCommonContainer(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.Operators
-
Find the innermost common
OperatorContainer
of two operators. - getCompiler() - Method in class org.apache.wayang.flink.execution.FlinkExecutor
-
Provide a
FunctionCompiler
. - getCompiler() - Method in class org.apache.wayang.java.execution.JavaExecutor
- getCompiler() - Method in class org.apache.wayang.spark.execution.SparkExecutor
-
Provide a
FunctionCompiler
. - getCompletedStages() - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
-
Retrieve the
ExecutionStage
s that have been completed so far. - getCompletionTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the completion time of this stage.
- getCompletionTime() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getCompletionTime() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getCompletionTime() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getCond0() - Method in class org.apache.wayang.iejoin.operators.IEJoinOperator
- getCond0() - Method in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- getCond1() - Method in class org.apache.wayang.iejoin.operators.IEJoinOperator
- getCond1() - Method in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- getConditionInputSlots() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getConditionInputSlots() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getConditionInputSlots() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getConditionInputSlots() - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getConditionInputSlots() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
Retrieve those
InputSlot
s that are required to evaluate the loop condition. - getConditionOutputSlots() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getConditionOutputSlots() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getConditionOutputSlots() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getConditionOutputSlots() - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getConditionOutputSlots() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
Retrieve those
OutputSlot
s that forward theLoopHeadOperator.getConditionInputSlots()
. - getConfiguration() - Method in class org.apache.wayang.api.sql.calcite.converter.WayangRelConverter
-
Some visitors may rely on configuration like the
WayangTableScanVisitor
, that uses it to specify its calcite schema when fetching from files on disk - getConfiguration() - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
- getConfiguration() - Method in class org.apache.wayang.core.api.configuration.ValueProvider
- getConfiguration() - Method in class org.apache.wayang.core.api.Job
-
Modify the
Configuration
to control theJob
execution. - getConfiguration() - Method in class org.apache.wayang.core.api.WayangContext
- getConfiguration() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
- getConfiguration() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getConfiguration() - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- getConfiguration() - Method in class org.apache.wayang.core.platform.ExecutorTemplate
- getConfiguration() - Method in class org.apache.wayang.java.compiler.FunctionCompiler
- getConfiguration() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getConfigurationKey() - Method in class org.apache.wayang.core.optimizer.costs.ConstantLoadProfileEstimator
- getConfigurationKey() - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Retrieve the
Configuration
key for this instance. - getConfigurationKey() - Method in class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
- getConfigurationKey() - Method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
- getConfigurationKeys() - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Retrieve the
Configuration
keys for this and all nested instances. - getConfigurationName() - Method in class org.apache.wayang.core.platform.Platform
-
Retrieve the name of this instance as it is used in
Configuration
keys. - getConnection() - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- getConsumer() - Method in class org.apache.wayang.basic.operators.KafkaTopicSource
- getConsumer() - Method in class org.apache.wayang.core.util.ConsumerIteratorAdapter
-
Retrieve the producer interface.
- getConsumer(Properties) - Method in class org.apache.wayang.basic.operators.KafkaTopicSource
- getConsumers() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getContainedOperator() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Retrieves the single(!)
- getContainedOperators() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Retrieves all
Operator
s that are immediately encased by this instance. - getContainer() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getContainer() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getContainers() - Method in interface org.apache.wayang.core.plan.wayangplan.CompositeOperator
-
Get the
OperatorContainer
s of this instance. - getContainers() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- getContainers() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- getConvergenceType() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getConvergenceType() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getConversionTasks() - Method in class org.apache.wayang.core.platform.Junction
- getCorrectnessProbability() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- getCorrectnessProbability() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- getCorrespondingSlots() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getCost() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getCostEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
-
Retrieve the cost estimate for this instance.
- getCostEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
-
Retrieve the cost estimate for this instance.
- getCostEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Retrieves the cost estimate for this instance including any overhead.
- getCostEstimate() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Get the estimated costs incurred by this instance (without fix costs).
- getCostEstimate(OptimizationContext) - Method in class org.apache.wayang.core.platform.Junction
-
Calculates the cost estimate for all
ExecutionOperator
s in this instance for a givenOptimizationContext
that should be known itself (or as a fork) to this instance. - getCostModel() - Method in class org.apache.wayang.core.api.Configuration
- getCostsPerMillisecond() - Method in class org.apache.wayang.core.optimizer.costs.TimeToCostConverter
-
Get the costs that incur per millisecond according to this instance.
- getCostSquasherProvider() - Method in class org.apache.wayang.core.api.Configuration
- getCpuCycles() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- getCpuCycles() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- getCpuUsage() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- getCriterion() - Method in class org.apache.wayang.basic.operators.DLTrainingOperator.Option
- getCriterion() - Method in class org.apache.wayang.tensorflow.model.TensorflowModel
- getCriterionDescriptor() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getCriterionDescriptor() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getCrossPlatformExecutor() - Method in class org.apache.wayang.core.api.Job
-
Provide the
CrossPlatformExecutor
used during the execution of this instance. - getCrossPlatformExecutor() - Method in interface org.apache.wayang.core.platform.Executor
-
If this instance is instrumented by a
CrossPlatformExecutor
, this method provides the latter. - getCrossPlatformExecutor() - Method in class org.apache.wayang.core.platform.ExecutorTemplate
- getCsvHeader() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- getCsvHeader() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- getCurrentIteration() - Method in interface org.apache.wayang.core.function.ExecutionContext
-
If this instance reflects the state of execution inside of a
LoopSubplan
, then retrieve the number of the current iteration. - getCurrentIteration() - Method in class org.apache.wayang.flink.execution.FlinkExecutionContext
- getCurrentIteration() - Method in class org.apache.wayang.java.execution.JavaExecutionContext
- getCurrentIteration() - Method in class org.apache.wayang.spark.execution.SparkExecutionContext
- getCurrentVertex() - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexReader
- getDampingFactor() - Method in class org.apache.wayang.basic.operators.PageRankOperator
- getData() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getDataQuantaType() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.ChannelNode
- getDatasetSize() - Method in class org.apache.wayang.basic.operators.SampleOperator
- getDataSetType() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getDataSource() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getDataUnitType() - Method in class org.apache.wayang.core.types.DataSetType
- getDeclaringJar(Class<?>) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Identifies and returns the JAR file declaring the given
Class
if no such file could be determined. - getDeclaringJar(Object) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Identifies and returns the JAR file declaring the
Class
of the givenobject
ornull
if no such file could be determined. - getDefaultConfiguration() - Static method in class org.apache.wayang.core.api.Configuration
-
Returns the global default instance.
- getDefaultOptimizationContexts() - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- getDefaultOptimizationContexts() - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
- getDefaultOptimizationContexts() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Get the
DefaultOptimizationContext
s represented by this instance. - getDefaultProperties() - Static method in class org.apache.wayang.basic.operators.KafkaTopicSink
- getDefaultProperties() - Static method in class org.apache.wayang.basic.operators.KafkaTopicSource
- getDefaults() - Static method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer.ConfigProperties
- getDenseValue(int) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- getDepth() - Method in interface org.apache.wayang.basic.model.DecisionTreeClassificationModel
- getDepth() - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator.Model
- getDescription() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- getDescriptor() - Method in class org.apache.wayang.basic.channels.FileChannel
- getDescriptor() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getDestination() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.Link
- getDetails() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the details of this stage.
- getDetails() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getDetails() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getDetails() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getDim() - Method in class org.apache.wayang.basic.model.op.ArgMax
- getDim() - Method in class org.apache.wayang.basic.model.op.Mean
- getDirectoryFileName(int) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- getDiskBytes() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- getDiskBytes() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- getDiskBytesSpilled() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the number of bytes spilled to disk by the task.
- getDiskBytesSpilled() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getDiskUsage() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- getDistribution() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableStatistic
- getDouble(int) - Method in class org.apache.wayang.basic.data.Record
-
Retrieve a field as a
double
. - getDouble(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- getDoubleProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getDoubleProperty(String, double) - Method in class org.apache.wayang.core.api.Configuration
- getDoubleProperty(String, double) - Method in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Retrieve a
double
-valued property in this context. - getDoubleProperty(String, double) - Method in class org.apache.wayang.core.optimizer.costs.SimpleEstimationContext
- getDoubleProperty(String, double) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getDoubleProperty(String, double) - Method in class org.apache.wayang.profiler.log.DynamicEstimationContext
- getDType() - Method in class org.apache.wayang.basic.model.op.Mean
- getDType() - Method in class org.apache.wayang.basic.model.op.nn.CrossEntropyLoss
- getDType() - Method in class org.apache.wayang.basic.model.op.nn.MSELoss
- getDType() - Method in class org.apache.wayang.basic.model.op.nn.ReLU
- getDType() - Method in class org.apache.wayang.basic.model.op.nn.Sigmoid
- getDType() - Method in class org.apache.wayang.basic.model.op.nn.Softmax
- getDType() - Method in class org.apache.wayang.basic.model.op.Op
- getDurationTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the duration time of this task.
- getDurationTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getDurationTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getDurationTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getEffectiveOccupant(int) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieves the effective occupant of the given
InputSlot
, i.e., theOutputSlot
that is either connected to the given or an outer-more, mappedInputSlot
. - getEffectiveOccupant(InputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieves the effective occupant of the given
InputSlot
, i.e., theOutputSlot
that is either connected to the given or an outer-more, mappedInputSlot
. - getEmployedVariables() - Method in class org.apache.wayang.profiler.log.DynamicLoadEstimator
-
Get the
Variable
s used in this instance. - getEmployedVariables() - Method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
- getEncoding() - Method in class org.apache.wayang.basic.operators.AmazonS3Source
- getEncoding() - Method in class org.apache.wayang.basic.operators.AzureBlobStorageSource
- getEncoding() - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- getEncoding() - Method in class org.apache.wayang.basic.operators.KafkaTopicSource
- getEncoding() - Method in class org.apache.wayang.basic.operators.TextFileSource
- getEnterJunction() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getEpoch() - Method in class org.apache.wayang.basic.operators.DLTrainingOperator.Option
- getEpoch() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Optional operation for non-composite operators.
- getEpoch() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getEpsilon() - Method in class org.apache.wayang.basic.model.op.nn.BatchNorm
- getEpsilon() - Method in class org.apache.wayang.basic.model.optimizer.Adam
- getEstimate(PlanImplementation, boolean) - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
-
Retrieves the cost estimate for this instance including any overhead.
- getEstimate(PlanImplementation, boolean) - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCost
- getEstimatedExecutionMillis() - Method in class org.apache.wayang.core.profiling.PartialExecutionMeasurement
- getEstimationContext() - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
- getEstimationContextProperties() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Collects all fields of this instance that have a
EstimationContextProperty
annotation. - getEventName() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Returns the name of the event associated with the application.
- getEventName() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the name of the event associated with this executor.
- getEventName() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Returns the name of the event associated with this job.
- getEventName() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the name of the event associated with this stage.
- getEventName() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Gets the name of the event associated with this task.
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getEventName() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getExcludedChannelConversions() - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- getExcludedChannelConversions() - Method in interface org.apache.wayang.core.plugin.Plugin
-
Provides the
ChannelConversion
s excluded by this instance. - getExcludedMappings() - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- getExcludedMappings() - Method in interface org.apache.wayang.core.plugin.Plugin
-
Provides the
Mapping
s excluded by this instance. - getExcludedRequiredPlatforms() - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- getExcludedRequiredPlatforms() - Method in interface org.apache.wayang.core.plugin.Plugin
-
Provides the required
Platform
s excluded by this instance. - getExecutedTasks() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
- getExecutionMillis() - Method in class org.apache.wayang.core.profiling.PartialExecutionMeasurement
- getExecutorCPUTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getExecutorDeserializeCpuTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the CPU time used for deserializing the task executor.
- getExecutorDeserializeCpuTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getExecutorDeserializeTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the time taken to deserialize the task executor.
- getExecutorDeserializeTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getExecutorFactory() - Method in class org.apache.wayang.core.platform.Platform
- getExecutorFactory() - Method in class org.apache.wayang.flink.platform.FlinkPlatform
- getExecutorFactory() - Method in class org.apache.wayang.genericjdbc.platform.GenericJdbcPlatform
- getExecutorFactory() - Method in class org.apache.wayang.giraph.platform.GiraphPlatform
- getExecutorFactory() - Method in class org.apache.wayang.java.platform.JavaPlatform
- getExecutorFactory() - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- getExecutorFactory() - Method in class org.apache.wayang.spark.platform.SparkPlatform
- getExecutorFactory() - Method in class org.apache.wayang.tensorflow.platform.TensorflowPlatform
- getExecutorHost() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the host where this executor is running.
- getExecutorHost() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getExecutorHost() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getExecutorHost() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getExecutorID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the ID of this executor.
- getExecutorID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the ID of the executor associated with this stage.
- getExecutorID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the ID of the executor assigned to this task.
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getExecutorID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getexecutorRunTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the total time taken by the task executor to run.
- getexecutorRunTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getExecutorTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the time at which this executor started.
- getExecutorTime() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getExecutorTime() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getExecutorTime() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getExitJunction() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getExperiment() - Method in class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Get the
Experiment
managed by this instance. - getExperiment() - Method in class org.apache.wayang.core.api.Job
-
Provide the
Experiment
being recorded with the execution of this instance. - getExpression(SchemaPlus, String) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getFactory() - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
- getFactory() - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCost
- getField(int) - Method in class org.apache.wayang.basic.data.Record
- getField0() - Method in class org.apache.wayang.basic.data.Tuple2
- getField0() - Method in class org.apache.wayang.basic.data.Tuple5
- getField0() - Method in class org.apache.wayang.core.util.Tuple
- getField1() - Method in class org.apache.wayang.basic.data.Tuple2
- getField1() - Method in class org.apache.wayang.basic.data.Tuple5
- getField1() - Method in class org.apache.wayang.core.util.Tuple
- getField2() - Method in class org.apache.wayang.basic.data.Tuple5
- getField3() - Method in class org.apache.wayang.basic.data.Tuple5
- getField4() - Method in class org.apache.wayang.basic.data.Tuple5
- getFieldNames() - Method in class org.apache.wayang.basic.function.ProjectionDescriptor
- getFieldNames() - Method in class org.apache.wayang.basic.types.RecordType
- getfilePathToCredentialsFile() - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- getFilePathToCredentialsFile() - Method in class org.apache.wayang.basic.operators.AmazonS3Source
- getFilePathToCredentialsFile() - Method in class org.apache.wayang.basic.operators.AzureBlobStorageSource
- getFileSize(String) - Method in interface org.apache.wayang.core.util.fs.FileSystem
-
Return the number of bytes of a given file.
- getFileSize(String) - Static method in class org.apache.wayang.core.util.fs.FileSystems
-
Determine the number of bytes of a given file.
- getFileSize(String) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- getFileSize(String) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- getFileSize(String) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- getFileSystem(String) - Static method in class org.apache.wayang.core.util.fs.FileSystems
- getFinalIterationContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- getFinalizationPusher(Configuration) - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getFinalizationPusher(Configuration) - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
Get the
CardinalityPusher
implementation for the final iteration. - getFinalLoopOutputs() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getFinalLoopOutputs() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getFinalLoopOutputs() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getFinalLoopOutputs() - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getFinalLoopOutputs() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
If this instance is the head of a loop, then return these
OutputSlot
s that form the final result of the iteration. - getFinalMax() - Static method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- getFinalMin() - Static method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- getFinalSum() - Static method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- getFinishTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the finish time of this task.
- getFinishTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getFinishTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getFinishTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getFitIntercept() - Method in class org.apache.wayang.basic.operators.LinearRegressionOperator
- getFitIntercept() - Method in class org.apache.wayang.basic.operators.LogisticRegressionOperator
- getFitness() - Method in class org.apache.wayang.profiler.log.Individual
- getFixCosts() - Method in class org.apache.wayang.core.optimizer.costs.TimeToCostConverter
-
Get the fix costs, i.e., the overhead, that incur according to this instance.
- getFlinkContext(Job) - Method in class org.apache.wayang.flink.platform.FlinkPlatform
-
Configures the single maintained
ExecutionEnvironment
according to thejob
and returns it. - getForwardJunction() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getForwards(InputSlot<?>) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getForwards(InputSlot<?>) - Method in class org.apache.wayang.basic.operators.LoopOperator
- getForwards(InputSlot<?>) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getForwards(InputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Declare forward rules.
- getFromList() - Method in class org.apache.wayang.basic.model.op.Op
- getFsPath() - Method in class org.apache.wayang.api.sql.calcite.utils.ModelParser
- getFunction(String) - Method in interface org.apache.wayang.core.util.mathex.Context
-
Provide the function.
- getFunction(String) - Method in class org.apache.wayang.core.util.mathex.DefaultContext
- getFunctionDescriptor() - Method in class org.apache.wayang.basic.operators.FlatMapOperator
- getFunctionDescriptor() - Method in class org.apache.wayang.basic.operators.MapOperator
- getFunctionDescriptor() - Method in class org.apache.wayang.basic.operators.MapPartitionsOperator
- getFunctionDescriptor() - Method in class org.apache.wayang.jdbc.operators.JdbcProjectionOperator
- getFunctionLoadProfileEstimatorProvider() - Method in class org.apache.wayang.core.api.Configuration
- getFunctionNames() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getFunctions() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getFunctions(String) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getGenericSqlQueryChannelDescriptor() - Method in class org.apache.wayang.genericjdbc.platform.GenericJdbcPlatform
- getGenome() - Method in class org.apache.wayang.profiler.log.Individual
- getGeometricMeanEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- getGeometricMeanEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- getGet0Pivot() - Method in class org.apache.wayang.iejoin.operators.IEJoinOperator
- getGet0Pivot() - Method in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- getGet0Ref() - Method in class org.apache.wayang.iejoin.operators.IEJoinOperator
- getGet0Ref() - Method in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- getGet1Pivot() - Method in class org.apache.wayang.iejoin.operators.IEJoinOperator
- getGet1Ref() - Method in class org.apache.wayang.iejoin.operators.IEJoinOperator
- getGettingTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the getting time of this task.
- getGettingTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getGettingTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getGettingTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getGiraphConfiguration() - Method in class org.apache.wayang.giraph.execution.GiraphExecutor
- getGrammarFileName() - Method in class org.apache.wayang.core.mathex.MathExLexer
- getGrammarFileName() - Method in class org.apache.wayang.core.mathex.MathExParser
- getGraphDensity() - Method in class org.apache.wayang.basic.operators.PageRankOperator
- getGson() - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Provide a
Gson
object. - getHeadTupleData() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- getHeadTupleValue() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- getHiddenDim() - Method in class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- getHostIP() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Gets the IP address of the host machine executing this task.
- getHostIP() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getHostIP() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getHostIP() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getId() - Method in class org.apache.wayang.basic.model.op.Op
- getId() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- getId() - Method in class org.apache.wayang.commons.util.profiledb.model.Measurement
- getId() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.ChannelNode
- getId() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- getId() - Method in class org.apache.wayang.profiler.log.Variable
- getID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the ID of this stage.
- getID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Gets the ID of this task.
- getID() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getID() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getID() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getInboundChannels() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- getInChannels() - Method in class org.apache.wayang.basic.model.op.nn.Conv
- getIndex() - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- getIndex() - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
- getIndex() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- getIndex() - Method in class org.apache.wayang.profiler.log.Variable
- getIndex() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the index of this task.
- getIndex() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getIndex() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getIndex() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getIndex(String) - Method in class org.apache.wayang.basic.types.RecordType
-
Returns the index of a field according to this instance.
- getIndices() - Method in class org.apache.wayang.ml4all.utils.SparseVector
- getIndividual() - Method in class org.apache.wayang.profiler.log.DynamicEstimationContext
- getInFeatures() - Method in class org.apache.wayang.basic.model.op.nn.Linear
- getInitialActivations(int) - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler
- getInitialActivations(int) - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal
- getInitialActivators() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler
- getInitialActivators() - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal
- getInitialIterationContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- getInitializationPusher(Configuration) - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getInitializationPusher(Configuration) - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
Get the
CardinalityPusher
implementation for the initial iteration. - getInitializedPlatforms() - Method in class org.apache.wayang.core.platform.PartialExecution
- getInitializeMillis(Configuration) - Method in class org.apache.wayang.core.platform.Platform
-
Get the time necessary to initialize this instance and use it for execution.
- getInitializeMillis(Configuration) - Method in class org.apache.wayang.spark.platform.SparkPlatform
- getInnerInputOptimizationContext(InputSlot<?>, OptimizationContext) - Method in class org.apache.wayang.core.plan.wayangplan.LoopSubplan
- getInnerInputOptimizationContext(InputSlot<?>, OptimizationContext) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Retrieve those
OptimizationContext
s that represent the state when this instance is entered. - getInnermostLoop() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getInnerOutputOptimizationContext(OptimizationContext) - Method in class org.apache.wayang.core.plan.wayangplan.LoopSubplan
- getInnerOutputOptimizationContext(OptimizationContext) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Retrieve that
OptimizationContext
that represents the state when this instance is exited. - getInput() - Method in class org.apache.wayang.core.plan.wayangplan.UnarySink
- getInput() - Method in class org.apache.wayang.core.plan.wayangplan.UnaryToUnaryOperator
- getInput(int) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieve an
InputSlot
of this instance using its index. - getInput(String) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieve an
InputSlot
of this instance by its name. - getInputCardinalities() - Method in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Provide the input
CardinalityEstimate
s for theOperator
that corresponds to this instance. - getInputCardinalities() - Method in class org.apache.wayang.core.optimizer.costs.SimpleEstimationContext
- getInputCardinalities() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getInputCardinalities() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- getInputCardinalities() - Method in class org.apache.wayang.profiler.log.DynamicEstimationContext
- getInputCardinalities() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- getInputCardinality(int) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getInputChannel(int) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getInputChannels() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler
- getInputChannels() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getInputDim() - Method in class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- getInputMatch() - Method in class org.apache.wayang.core.mapping.SubplanMatch
- getInputPattern() - Method in class org.apache.wayang.core.mapping.SubplanPattern
- getInputSlotFor(Channel) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getInputStream() - Method in class org.apache.wayang.basic.operators.AmazonS3Source
-
Retrieves an InputStream to the specified S3 blob file.
- getInputStream() - Method in class org.apache.wayang.basic.operators.AzureBlobStorageSource
-
Retrieves an InputStream to the specified Azure blob file.
- getInputStream() - Method in class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- getInputType() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getInputType() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getInputType() - Method in class org.apache.wayang.core.function.AggregationDescriptor
- getInputType() - Method in class org.apache.wayang.core.function.ConsumerDescriptor
- getInputType() - Method in class org.apache.wayang.core.function.FlatMapDescriptor
- getInputType() - Method in class org.apache.wayang.core.function.MapPartitionsDescriptor
- getInputType() - Method in class org.apache.wayang.core.function.PredicateDescriptor
- getInputType() - Method in class org.apache.wayang.core.function.ReduceDescriptor
- getInputType() - Method in class org.apache.wayang.core.function.TransformationDescriptor
- getInputType() - Method in class org.apache.wayang.core.plan.wayangplan.UnaryToUnaryOperator
- getInputType0() - Method in class org.apache.wayang.core.plan.wayangplan.BinaryToUnaryOperator
- getInputType1() - Method in class org.apache.wayang.core.plan.wayangplan.BinaryToUnaryOperator
- getInputUrl() - Method in class org.apache.wayang.basic.operators.ObjectFileSource
- getInputUrl() - Method in class org.apache.wayang.basic.operators.ParquetSource
- getInputUrl() - Method in class org.apache.wayang.basic.operators.TextFileSource
- getInstance() - Static method in class org.apache.wayang.flink.platform.FlinkPlatform
- getInstance() - Static method in class org.apache.wayang.genericjdbc.platform.GenericJdbcPlatform
- getInstance() - Static method in class org.apache.wayang.giraph.platform.GiraphPlatform
- getInstance() - Static method in class org.apache.wayang.java.platform.JavaPlatform
- getInstance() - Static method in class org.apache.wayang.postgres.platform.PostgresPlatform
- getInstance() - Static method in class org.apache.wayang.spark.platform.SparkPlatform
- getInstance() - Static method in class org.apache.wayang.sqlite3.platform.Sqlite3Platform
- getInstance() - Static method in class org.apache.wayang.tensorflow.platform.TensorflowPlatform
- getInstrumentationStrategyProvider() - Method in class org.apache.wayang.core.api.Configuration
- getInt(int) - Method in class org.apache.wayang.basic.data.Record
-
Retrieve a field as a
int
. - getInt(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- getInterBodyJunction() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getIntercept() - Method in interface org.apache.wayang.basic.model.LinearRegressionModel
- getIntercept() - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator.Model
- getInterface() - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- getInterfaceOperators() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getInvolvedPlatforms() - Method in class org.apache.wayang.core.platform.PartialExecution
-
Retrieve the
Platform
s involved in this instance. - getIterable() - Method in class org.apache.wayang.api.python.executor.ProcessReceiver
- getIterationContext(int) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- getIterationContexts() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
-
Retrieves the iteration
OptimizationContext
s. - getIterationImplementations() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
- getIterationNumber() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getIterator() - Method in class org.apache.wayang.core.util.ConsumerIteratorAdapter
-
Retrieve the consumer interface.
- getJavaImplementation() - Method in class org.apache.wayang.core.function.AggregationDescriptor
-
This is function is not built to last.
- getJavaImplementation() - Method in class org.apache.wayang.core.function.ConsumerDescriptor
-
This function is not built to last.
- getJavaImplementation() - Method in class org.apache.wayang.core.function.FlatMapDescriptor
-
This is function is not built to last.
- getJavaImplementation() - Method in class org.apache.wayang.core.function.MapPartitionsDescriptor
-
This is function is not built to last.
- getJavaImplementation() - Method in class org.apache.wayang.core.function.PredicateDescriptor
-
This function is not built to last.
- getJavaImplementation() - Method in class org.apache.wayang.core.function.ReduceDescriptor
-
This is function is not built to last.
- getJavaImplementation() - Method in class org.apache.wayang.core.function.TransformationDescriptor
-
This is function is not built to last.
- getJdbcDriverClassName() - Method in class org.apache.wayang.genericjdbc.platform.GenericJdbcPlatform
- getJdbcDriverClassName() - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
-
Provide the name of the JDBC driver
Class
for this instance. - getJdbcDriverClassName() - Method in class org.apache.wayang.postgres.platform.PostgresPlatform
- getJdbcDriverClassName() - Method in class org.apache.wayang.sqlite3.platform.Sqlite3Platform
- getJdbcName() - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Instance
- getJdbcTableType() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- getJob() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Provide the
Job
whose optimization is supported by this instance. - getJob() - Method in class org.apache.wayang.core.platform.PushExecutorTemplate
-
Provide the
Job
that is processed by this instance. - getJobID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Returns the unique identifier for this job.
- getJobID() - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- getJobID() - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- getJoinOperator(Integer[], Integer[], WayangJoin, String, String, String, String) - Method in class org.apache.wayang.api.sql.calcite.converter.WayangMultiConditionJoinVisitor
-
This method handles the
JoinOperator
creation - getJSONArray(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- getJSONObject(int) - Method in class org.apache.wayang.core.util.json.WayangJsonArray
- getJSONObject(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- getJunction(OutputSlot<?>) - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
-
Retrieves the
Junction
that implements the givenoutput
. - getJunction(OutputSlot<?>) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getJunctions() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getJVMGCTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the amount of time spent by the JVM on garbage collection.
- getJVMGCTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getK() - Method in interface org.apache.wayang.basic.model.KMeansModel
- getK() - Method in class org.apache.wayang.basic.operators.KMeansOperator
- getK() - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator.Model
- getKernelSize() - Method in class org.apache.wayang.basic.model.op.nn.Conv
- getKernelSize() - Method in class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- getKey() - Method in class org.apache.wayang.basic.model.op.Get
- getKey() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- getKey() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- getKey(T) - Method in class org.apache.wayang.flink.compiler.KeySelectorDistinct
- getKey(T) - Method in class org.apache.wayang.flink.compiler.KeySelectorFunction
- getKeyDescriptor() - Method in class org.apache.wayang.basic.operators.GroupByOperator
- getKeyDescriptor() - Method in class org.apache.wayang.basic.operators.MaterializedGroupByOperator
- getKeyDescriptor() - Method in class org.apache.wayang.basic.operators.ReduceByOperator
- getKeyDescriptor() - Method in class org.apache.wayang.basic.operators.SortOperator
- getKeyDescriptor0() - Method in class org.apache.wayang.basic.operators.CoGroupOperator
- getKeyDescriptor0() - Method in class org.apache.wayang.basic.operators.JoinOperator
- getKeyDescriptor1() - Method in class org.apache.wayang.basic.operators.CoGroupOperator
- getKeyDescriptor1() - Method in class org.apache.wayang.basic.operators.JoinOperator
- getKeys() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableStatistic
- getLabel() - Method in class org.apache.wayang.ml4all.utils.SparseVector
- getLabels() - Method in class org.apache.wayang.basic.model.op.nn.CrossEntropyLoss
- getLastUpdateMillis() - Method in class org.apache.wayang.profiler.util.RrdAccessor
- getLaunchTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the launch time of this task.
- getLaunchTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getLaunchTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getLaunchTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getLearningRate() - Method in class org.apache.wayang.basic.model.optimizer.Optimizer
- getLimitBaseKey() - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Provides a base key for configuring input and output limits.
- getLineage() - Method in class org.apache.wayang.core.platform.AbstractChannelInstance
- getLineage() - Method in interface org.apache.wayang.core.platform.ChannelInstance
-
Provides a
ChannelLineageNode
that keeps around (at least) all non-executed predecessorChannelInstance
s andOptimizationContext.OperatorContext
s. - getLinks() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement
- getList1() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- getListOfjobs() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Returns the list of jobs associated with the application.
- getListOfjobs() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- getListOfjobs() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- getListOfStages() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Returns the list of stages comprising this job.
- getListOfStages() - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- getListOfStages() - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- getListOfTasks() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Retrieves the list of tasks to be performed.
- getListOfTasks() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getListOfTasks() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getListOfTasks() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getLoadProfile() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getLoadProfileEstimator() - Method in class org.apache.wayang.core.function.FunctionDescriptor
- getLoadProfileEstimator() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Get the
LoadProfileEstimator
for theExecutionOperator
in this instance. - getLoadProfileEstimator() - Method in class org.apache.wayang.core.platform.AtomicExecution
-
Retrieve the
LoadProfileEstimator
encapsulated by this instance. - getLoadProfileEstimatorCache() - Method in class org.apache.wayang.core.api.Configuration
- getLoadProfileEstimatorConfigurationKey() - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Deprecated.
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkCartesianOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkCollectionSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkCollectionSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkCountOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkDistinctOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkFilterOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkGroupByOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkIntersectOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkJoinOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkLoopOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkMapOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkReduceByOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkRepeatOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkSampleOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkSortOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkTsvFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkUnionAllOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.graph.JavaPageRankOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaCollectionSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaCollectOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaCountOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaDistinctOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaDoWhileOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaFilterOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaFlatMapOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaGlobalReduceOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaLocalCallbackSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaLoopOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaMapOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaMapPartitionsOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaObjectFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaObjectFileSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaReduceByOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaRepeatOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaSortOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaTextFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaTsvFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaTsvFileSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.java.operators.JavaUnionAllOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.jdbc.operators.JdbcFilterOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.jdbc.operators.JdbcJoinOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.jdbc.operators.JdbcProjectionOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.jdbc.operators.JdbcTableSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkBroadcastOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkCacheOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkCartesianOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkCoGroupOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkCollectionSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkCollectOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkCountOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkDistinctOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkDoWhileOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkFilterOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkFlatMapOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkIntersectOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkJoinOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkLocalCallbackSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkLoopOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkMapOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkObjectFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkObjectFileSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkReduceByOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkRepeatOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkSortOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkTextFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkTsvFileSink
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkTsvFileSource
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkUnionAllOperator
- getLoadProfileEstimatorConfigurationKey() - Method in class org.apache.wayang.spark.operators.SparkZipWithIdOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Provide the
Configuration
keys for theLoadProfileEstimator
specification of this instance. - getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.flink.operators.FlinkTextFileSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaAmazonS3Source
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaAzureBlobStorageSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaCartesianOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaCoGroupOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaGoogleCloudStorageSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaIntersectOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaJoinOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaParquetSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaRandomSampleOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaReservoirSampleOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.java.operators.JavaTextFileSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.spark.operators.SparkParquetSource
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
- getLoadProfileEstimatorConfigurationKeys() - Method in class org.apache.wayang.spark.operators.SparkTextFileSource
- getLoadProfileEstimatorConfigurationTypeKey() - Method in class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- getLoadProfileToTimeConverterProvider() - Method in class org.apache.wayang.core.api.Configuration
- getLocalOperatorContexts() - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- getLocalOperatorContexts() - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
- getLocalOperatorContexts() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getLocation() - Method in class org.apache.wayang.basic.channels.FileChannel.Descriptor
- getLong(int) - Method in class org.apache.wayang.basic.data.Record
-
Retrieve a field as a
long
. - getLong(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- getLongProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getLongProperty(String, long) - Method in class org.apache.wayang.core.api.Configuration
- getLoop() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- getLoop() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Retrieve the (innermost)
ExecutionStageLoop
that this instance is part of. - getLoopBodyInputs() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getLoopBodyInputs() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getLoopBodyInputs() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getLoopBodyInputs() - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getLoopBodyInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
- getLoopBodyOutputs() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getLoopBodyOutputs() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getLoopBodyOutputs() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getLoopBodyOutputs() - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getLoopBodyOutputs() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
If this instance is the head of a loop, then return these
OutputSlot
s that go into the loop body (as opposed to theOutputSlot
s that form the final result of the iteration). - getLoopContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Retrieve the
OptimizationContext.LoopContext
in which this instance resides. - getLoopHead() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStageLoop
-
Retrieves the
ExecutionStage
that contains theLoopHeadOperator
of this instance. - getLoopHead() - Method in class org.apache.wayang.core.plan.wayangplan.LoopSubplan
- getLoopHeadTask() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Retrieves the
LoopHeadOperator
ExecutionTask
in this instance. - getLoopImplementation() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getLoopImplementations() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getLoopInitializationInputs() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getLoopInitializationInputs() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getLoopInitializationInputs() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getLoopInitializationInputs() - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getLoopInitializationInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
If this instance is the head of a loop, then return these
InputSlot
s that initialize the loop. - getLoopStack() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getLoopSubplan() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStageLoop
-
Retrieve the
LoopSubplan
encapsulated by this instance. - getLoopSubplanContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- getLowerCost() - Method in class org.apache.wayang.core.profiling.CostMeasurement
- getLowerEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- getLowerEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- getMappedInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Get those
InputSlot
s within this instance, that are mapped via theSlotMapping
. - getMappedOutputs() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Get those
OutputSlot
s within this instance, that are mapped via theSlotMapping
. - getMappingProvider() - Method in class org.apache.wayang.core.api.Configuration
- getMappings() - Method in class org.apache.wayang.basic.plugin.WayangBasic
- getMappings() - Method in class org.apache.wayang.basic.plugin.WayangBasicGraph
- getMappings() - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- getMappings() - Method in interface org.apache.wayang.core.plugin.Plugin
-
Provides the
Mapping
s shipped with this instance. - getMappings() - Method in class org.apache.wayang.flink.plugin.FlinkBasicPlugin
- getMappings() - Method in class org.apache.wayang.flink.plugin.FlinkConversionPlugin
- getMappings() - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcConversionsPlugin
- getMappings() - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcPlugin
- getMappings() - Method in class org.apache.wayang.giraph.plugin.GiraphPlugin
- getMappings() - Method in class org.apache.wayang.java.plugin.JavaBasicPlugin
- getMappings() - Method in class org.apache.wayang.java.plugin.JavaChannelConversionPlugin
- getMappings() - Method in class org.apache.wayang.java.plugin.JavaGraphPlugin
- getMappings() - Method in class org.apache.wayang.postgres.plugin.PostgresConversionsPlugin
- getMappings() - Method in class org.apache.wayang.postgres.plugin.PostgresPlugin
- getMappings() - Method in class org.apache.wayang.spark.plugin.SparkBasicPlugin
- getMappings() - Method in class org.apache.wayang.spark.plugin.SparkConversionPlugin
- getMappings() - Method in class org.apache.wayang.spark.plugin.SparkGraphPlugin
- getMappings() - Method in class org.apache.wayang.spark.plugin.SparkMLPlugin
- getMappings() - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3ConversionPlugin
- getMappings() - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3Plugin
- getMappings() - Method in class org.apache.wayang.tensorflow.plugin.TensorflowConversionPlugin
- getMappings() - Method in class org.apache.wayang.tensorflow.plugin.TensorflowPlugin
- getMatch(String) - Method in class org.apache.wayang.core.mapping.SubplanMatch
- getMaxDepth() - Method in class org.apache.wayang.basic.operators.DecisionTreeRegressionOperator
- getMaximumEpoch() - Method in class org.apache.wayang.core.mapping.SubplanMatch
- getMaximumNumberOfSplits() - Method in class org.apache.wayang.flink.operators.CollectionSplittableIterator
- getMaxIter() - Method in class org.apache.wayang.basic.operators.LinearSVCOperator
- getMeasuredCardinality() - Method in class org.apache.wayang.core.platform.AbstractChannelInstance
- getMeasuredCardinality() - Method in interface org.apache.wayang.core.platform.ChannelInstance
-
Optionally provides the measured cardinality of this instance.
- getMeasuredCardinality() - Method in class org.apache.wayang.flink.channels.DataSetChannel.Instance
- getMeasuredCardinality() - Method in class org.apache.wayang.java.channels.StreamChannel.Instance
- getMeasuredCardinality() - Method in class org.apache.wayang.spark.channels.RddChannel.Instance
- getMeasuredCardinality() - Method in class org.apache.wayang.tensorflow.channels.TensorChannel.Instance
- getMeasuredExecutionTime() - Method in class org.apache.wayang.core.platform.PartialExecution
- getMeasuredLowerCost() - Method in class org.apache.wayang.core.platform.PartialExecution
-
The lower cost for this instance (without fix costs).
- getMeasuredUpperCost() - Method in class org.apache.wayang.core.platform.PartialExecution
-
The upper cost for this instance (without fix costs).
- getMeasurements() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- getMetadata() - Method in class org.apache.wayang.basic.operators.ParquetSource
- getMillis() - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
- getMinInstancesPerNode() - Method in class org.apache.wayang.basic.operators.DecisionTreeRegressionOperator
- getModeNames() - Method in class org.apache.wayang.core.mathex.MathExLexer
- getModifiableCollection() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- getMomentum() - Method in class org.apache.wayang.basic.model.op.nn.BatchNorm
- getName() - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- getName() - Method in enum class org.apache.wayang.basic.model.op.Input.Type
- getName() - Method in class org.apache.wayang.basic.model.op.Op
- getName() - Method in class org.apache.wayang.basic.model.optimizer.Optimizer
- getName() - Method in class org.apache.wayang.core.api.Configuration
- getName() - Method in class org.apache.wayang.core.api.Job
-
Retrieves the name of this instance.
- getName() - Method in class org.apache.wayang.core.mapping.OperatorPattern
- getName() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Provides an instance's name.
- getName() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getName() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- getName() - Method in class org.apache.wayang.core.platform.Platform
- getName() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- getName() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Returns the name of the application.
- getName() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- getName() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- getNestedEstimators() - Method in class org.apache.wayang.core.optimizer.costs.ConstantLoadProfileEstimator
- getNestedEstimators() - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Retrieve nested instances.
- getNestedEstimators() - Method in class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
- getNestedEstimators() - Method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
- getNestedLoopContext(LoopSubplan) - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- getNestedLoopContext(LoopSubplan) - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Retrieve the
OptimizationContext.LoopContext
for theloopSubplan
. - getNestedLoopContext(LoopSubplan) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Retrieve the
OptimizationContext.LoopContext
for theloopSubplan
. - getNetworkBytes() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- getNetworkBytes() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- getNetworkUsage() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- getNextIterationContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getNode() - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- getNormalizedEstimationContext() - Method in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Provide a normalized instance, that has only a single execution.
- getNumAlternatives() - Method in class org.apache.wayang.core.plan.wayangplan.PlanMetrics
-
Provide the number of
OperatorAlternative
s in theWayangPlan
. - getNumberOfTasks() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the number of tasks associated with this stage.
- getNumberOfTasks() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getNumberOfTasks() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getNumberOfTasks() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getNumBroadcastInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getNumCombinations() - Method in class org.apache.wayang.core.plan.wayangplan.PlanMetrics
- getNumDefaultPartitions() - Method in class org.apache.wayang.flink.execution.FlinkExecutor
- getNumDefaultPartitions() - Method in class org.apache.wayang.spark.execution.SparkExecutor
-
Hint to
SparkExecutionOperator
s on how many partitions they should request. - getNumDimensions() - Method in class org.apache.wayang.profiler.log.OptimizationSpace
- getNumExecutionOperators() - Method in class org.apache.wayang.core.plan.wayangplan.PlanMetrics
-
Provide the number of
ExecutionOperator
s in theWayangPlan
. - getNumExecutions() - Method in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Retrieve the number of executions to be estimated.
- getNumExecutions() - Method in class org.apache.wayang.core.optimizer.costs.SimpleEstimationContext
- getNumExecutions() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getNumExecutions() - Method in class org.apache.wayang.profiler.log.DynamicEstimationContext
- getNumExpectedIterations() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getNumExpectedIterations() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getNumExpectedIterations() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getNumExpectedIterations() - Method in class org.apache.wayang.core.plan.wayangplan.LoopHeadAlternative
- getNumExpectedIterations() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
- getNumExpectedIterations() - Method in class org.apache.wayang.core.plan.wayangplan.LoopSubplan
- getNumFeatures() - Method in class org.apache.wayang.basic.model.op.nn.BatchNorm
- getNumInitialActivations() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler
- getNumInitialActivations() - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal
- getNumInputChannels() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getNumInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getNumIterations() - Method in class org.apache.wayang.basic.operators.PageRankOperator
- getNumIterations() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getNumIterations() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getNumObservations() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getNumOuputChannels() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getNumOutputs() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getNumReadBytes() - Method in class org.apache.wayang.core.util.LimitedInputStream
- getNumReferences() - Method in class org.apache.wayang.core.util.AbstractReferenceCountable
- getNumReferences() - Method in interface org.apache.wayang.core.util.ReferenceCountable
-
Tells the number of references on this instance.
- getNumRegularInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- getNumTargets() - Method in class org.apache.wayang.core.platform.Junction
- getNumVirtualOperators() - Method in class org.apache.wayang.core.plan.wayangplan.PlanMetrics
-
Provide the number of virtual
Operator
s in theWayangPlan
. - getObservations() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getOccupant() - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- getOccupiedSlots() - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
- getOpenInputChannels() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
Collects all
Channel
s that are copies. - getOperator() - Method in class org.apache.wayang.core.mapping.OperatorMatch
- getOperator() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- getOperator() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getOperator() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getOperator() - Method in class org.apache.wayang.profiler.java.BinaryOperatorProfiler
- getOperator() - Method in class org.apache.wayang.profiler.java.OperatorProfiler
- getOperator() - Method in class org.apache.wayang.profiler.java.UnaryOperatorProfiler
- getOperatorAlternative() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- getOperatorContext() - Method in class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
-
Retrieve the
OptimizationContext.OperatorContext
corresponding to this instance. - getOperatorContext(Operator) - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- getOperatorContext(Operator) - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
-
Return the
OptimizationContext.OperatorContext
of theoperator
. - getOperatorContext(Operator) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Return the
OptimizationContext.OperatorContext
of theoperator
. - getOperatorLoadProfileEstimatorProvider() - Method in class org.apache.wayang.core.api.Configuration
- getOperatorMatches() - Method in class org.apache.wayang.core.mapping.SubplanMatch
- getOperators() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getOperators() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement
- getOptimizationContext() - Method in class org.apache.wayang.core.api.Job
- getOptimizationContext() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- getOptimizationContext() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- getOptimizationContext() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getOptimizationContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- getOptimizationContext() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getOptimizationContexts() - Method in class org.apache.wayang.core.platform.Junction
-
Retrieve the
OptimizationContext
s that hold optimization information on theExecutionOperator
s in this instance. - getOptimizationSpace() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getOptimizer() - Method in class org.apache.wayang.basic.operators.DLTrainingOperator.Option
- getOptimizer() - Method in class org.apache.wayang.tensorflow.model.TensorflowModel
- getOptionalBooleanProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getOptionalDoubleProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getOptionalLongProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getOptionalStringProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getOrAdd(T) - Method in class org.apache.wayang.core.util.Canonicalizer
-
Add the given element if it is not contained in this instance, yet.
- getOrCreateRound(String) - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
-
Retrieves an existing
TimeMeasurement
fromTimeMeasurement.rounds
with the givenid
or creates and stores a new one. - getOrCreateRound(String, String...) - Method in class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Retrieves a
TimeMeasurement
by its ID fromStopWatch.rounds
. - getOrCreateVariable(String) - Method in class org.apache.wayang.profiler.log.OptimizationSpace
- getOriginal() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getOriginal() - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
- getOriginal() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getOut() - Method in class org.apache.wayang.basic.model.DLModel
- getOutboundChannels() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- getOutChannels() - Method in class org.apache.wayang.basic.model.op.nn.Conv
- getOuterInputSlot(InputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieve the
InputSlot
of the enclosingOperatorContainer
that represents the given one. - getOutermostInputSlot(InputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieve the outermost
InputSlot
if this operator is nested in other operators. - getOutermostOutputSlots(OutputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieve the outermost
OutputSlot
s if this operator is nested in other operators. - getOuterSourceOutputs() - Method in class org.apache.wayang.core.platform.Junction
- getOutFeatures() - Method in class org.apache.wayang.basic.model.op.nn.Linear
- getOutput() - Method in class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- getOutput() - Method in class org.apache.wayang.basic.operators.UnionAllOperator
- getOutput() - Method in class org.apache.wayang.core.plan.wayangplan.UnarySource
- getOutput() - Method in class org.apache.wayang.core.plan.wayangplan.UnaryToUnaryOperator
- getOutput(int) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieve an
OutputSlot
of this instance using its index. - getOutput(String) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Retrieve an
OutputSlot
of this instance by its name. - getOutputCardinalities() - Method in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Provide the output
CardinalityEstimate
s for theOperator
that corresponds to this instance. - getOutputCardinalities() - Method in class org.apache.wayang.core.optimizer.costs.SimpleEstimationContext
- getOutputCardinalities() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getOutputCardinalities() - Method in class org.apache.wayang.profiler.log.DynamicEstimationContext
- getOutputCardinality() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- getOutputCardinality() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- getOutputCardinality(int) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getOutputChannel(int) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getOutputChannelDescriptor(int) - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Display the
Channel
used to implement a certainOutputSlot
. - getOutputChannels() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getOutputDirectoryMode() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- getOutputFilePath() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- getOutputMatch() - Method in class org.apache.wayang.core.mapping.SubplanMatch
- getOutputPattern() - Method in class org.apache.wayang.core.mapping.SubplanPattern
- getOutputSlot() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- getOutputSlotFor(Channel) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getOutputType() - Method in class org.apache.wayang.core.function.AggregationDescriptor
- getOutputType() - Method in class org.apache.wayang.core.function.FlatMapDescriptor
- getOutputType() - Method in class org.apache.wayang.core.function.MapPartitionsDescriptor
- getOutputType() - Method in class org.apache.wayang.core.function.ReduceDescriptor
- getOutputType() - Method in class org.apache.wayang.core.function.TransformationDescriptor
- getOutputType() - Method in class org.apache.wayang.core.plan.wayangplan.BinaryToUnaryOperator
- getOutputType() - Method in class org.apache.wayang.core.plan.wayangplan.UnaryToUnaryOperator
- getOverallTimeEstimate() - Method in class org.apache.wayang.core.platform.Junction
-
Determines the
TimeEstimate
for allExecutionOperator
s in this instance across all of itsOptimizationContext
s. - getOverallTimeEstimate(Configuration) - Method in class org.apache.wayang.core.platform.PartialExecution
-
Calculates the overall
TimeEstimate
of this instance. - getOverheadMillis() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- getOwner() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- getPadding() - Method in class org.apache.wayang.basic.model.op.nn.Conv
- getParallelEstimate(PlanImplementation, boolean) - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
-
Retrieves the cost estimate for this instance taking into account parallel stage execution.
- getParallelEstimate(PlanImplementation, boolean) - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCost
- getParallelOperatorJunctionAllCostEstimate(PlanImplementation, Operator) - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
- getParallelOperatorJunctionAllCostEstimate(PlanImplementation, Operator) - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCost
- getParameter(PageRankParameters.PageRankEnum) - Static method in class org.apache.wayang.giraph.Algorithm.PageRankParameters
- getParameters() - Method in class org.apache.wayang.basic.operators.PyWayangReduceByOperator
- getParent() - Method in class org.apache.wayang.core.api.Configuration
- getParent() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getParent() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Operators can be nested in other operators, e.g., in a
Subplan
or aOperatorAlternative
. - getPartialExecutions() - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- getPartialExecutions() - Method in interface org.apache.wayang.core.platform.ExecutionState
-
Retrieves previously stored
PartialExecution
s. - getPartition() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the partition of this task.
- getPartition() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getPartition() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getPartition() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getPartitionID() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- getPathOut(Configuration) - Method in class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- getPaths() - Method in class org.apache.wayang.basic.channels.FileChannel.Instance
- getPattern() - Method in class org.apache.wayang.core.mapping.OperatorMatch
- getPattern() - Method in class org.apache.wayang.core.mapping.SubplanMatch
- getPeakExecutionMemory() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the peak execution memory used by the task executor.
- getPeakExecutionMemory() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getPerm() - Method in class org.apache.wayang.basic.model.op.Transpose
- getPlaceholders(Operand<?>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm2D
- getPlanAsString() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Prints the instance's
ExecutionTask
s andChannel
s. - getPlanAsString(String) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Prints the instance's
ExecutionTask
s andChannel
s. - getPlanAsString(StringBuilder, String) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- getPlanEnumeration() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- getPlanImplementations() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
- getPlanTraversal() - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimatorManager
- getPlatform() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getPlatform() - Method in class org.apache.wayang.core.plan.executionplan.PlatformExecution
- getPlatform() - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
- getPlatform() - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
- getPlatform() - Method in interface org.apache.wayang.core.platform.Executor
- getPlatform() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- getPlatform() - Method in class org.apache.wayang.flink.execution.FlinkExecutor
- getPlatform() - Method in interface org.apache.wayang.flink.operators.FlinkExecutionOperator
- getPlatform() - Method in class org.apache.wayang.genericjdbc.execution.GenericJdbcExecutor
- getPlatform() - Method in interface org.apache.wayang.genericjdbc.operators.GenericJdbcExecutionOperator
- getPlatform() - Method in class org.apache.wayang.giraph.execution.GiraphExecutor
- getPlatform() - Method in class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- getPlatform() - Method in class org.apache.wayang.java.execution.JavaExecutor
- getPlatform() - Method in interface org.apache.wayang.java.operators.JavaExecutionOperator
- getPlatform() - Method in class org.apache.wayang.jdbc.execution.JdbcExecutor
- getPlatform() - Method in interface org.apache.wayang.jdbc.operators.JdbcExecutionOperator
- getPlatform() - Method in interface org.apache.wayang.postgres.operators.PostgresExecutionOperator
- getPlatform() - Method in class org.apache.wayang.spark.execution.SparkExecutor
- getPlatform() - Method in interface org.apache.wayang.spark.operators.SparkExecutionOperator
- getPlatform() - Method in class org.apache.wayang.sqlite3.operators.Sqlite3FilterOperator
- getPlatform() - Method in class org.apache.wayang.sqlite3.operators.Sqlite3ProjectionOperator
- getPlatform() - Method in class org.apache.wayang.sqlite3.operators.Sqlite3TableSource
- getPlatform() - Method in class org.apache.wayang.tensorflow.execution.TensorflowExecutor
- getPlatform() - Method in interface org.apache.wayang.tensorflow.operators.TensorflowExecutionOperator
- getPlatformExecution() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- getPlatformId() - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
-
Provide a unique identifier for this kind of platform.
- getPlatformOverheads() - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getPlatformProvider() - Method in class org.apache.wayang.core.api.Configuration
- getPlatformStartUpTimeProvider() - Method in class org.apache.wayang.core.api.Configuration
- getPredecessorChannel(Channel) - Static method in class org.apache.wayang.core.optimizer.OptimizationUtils
- getPredecessors() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- getPredicateDescriptor() - Method in class org.apache.wayang.basic.operators.FilterOperator
- getProbability() - Method in class org.apache.wayang.core.profiling.CostMeasurement
- getProcess() - Method in class org.apache.wayang.api.python.executor.PythonProcessCaller
- getProducedType() - Method in class org.apache.wayang.flink.compiler.criterion.DummyFilter
- getProducedType() - Method in class org.apache.wayang.flink.compiler.criterion.DummyMap
- getProducedType() - Method in class org.apache.wayang.flink.compiler.KeySelectorFunction
- getProducer() - Method in class org.apache.wayang.basic.operators.KafkaTopicSink
- getProducer() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getProducer(Properties) - Method in class org.apache.wayang.basic.operators.KafkaTopicSink
- getProducerOperator() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Try to obtain the
ExecutionOperator
producing this instance, either from a givenOutputSlot
or aExecutionTask
that was specified as producer. - getProducerOperatorContext() - Method in class org.apache.wayang.core.platform.AbstractChannelInstance
- getProducerOperatorContext() - Method in interface org.apache.wayang.core.platform.ChannelInstance
-
Retrieve the
OptimizationContext.OperatorContext
of theExecutionOperator
producing this instance. - getProducerSlot() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getProductArity() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Returns the number of output products produced by this job.
- getProductArity() - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- getProductArity() - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- getProjection() - Method in class org.apache.wayang.basic.operators.ParquetSource
- getProperties() - Method in class org.apache.wayang.core.api.Configuration
- getProperty(Object, String) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Retrieve a property from an object.
- getPropertyKeys() - Method in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Retrieve the eligible property keys for
EstimationContext.getDoubleProperty(String, double)
. - getPropertyKeys() - Method in class org.apache.wayang.core.optimizer.costs.SimpleEstimationContext
- getPropertyKeys() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getPropertyKeys() - Method in class org.apache.wayang.profiler.log.DynamicEstimationContext
- getPruningStrategies() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- getPruningStrategyClassProvider() - Method in class org.apache.wayang.core.api.Configuration
- getQualifiedName() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- getRamUsage() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- getRange() - Method in class org.apache.wayang.basic.model.op.Slice
- getRank() - Method in class org.apache.wayang.iejoin.data.Data
- getReasonOfRemoval() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the reason for which this executor was removed from the cluster.
- getReasonOfRemoval() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getReasonOfRemoval() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getReasonOfRemoval() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getRecordsWrittern() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Returns the number of records written by the task.
- getRecordsWrittern() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getReduceDescriptor() - Method in class org.apache.wayang.basic.operators.GlobalReduceOperator
- getReduceDescriptor() - Method in class org.apache.wayang.basic.operators.PyWayangReduceByOperator
- getReduceDescriptor() - Method in class org.apache.wayang.basic.operators.ReduceByOperator
- getReduceDescriptor() - Method in class org.apache.wayang.basic.operators.ReduceOperator
- getReferentialConstraints() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableStatistic
- getRegParam() - Method in class org.apache.wayang.basic.operators.LinearSVCOperator
- getRequestedInputSlots() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
- getRequiredPlatforms() - Method in class org.apache.wayang.basic.plugin.WayangBasic
- getRequiredPlatforms() - Method in class org.apache.wayang.basic.plugin.WayangBasicGraph
- getRequiredPlatforms() - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- getRequiredPlatforms() - Method in interface org.apache.wayang.core.plugin.Plugin
-
Provides the
Platform
s required by this instance. - getRequiredPlatforms() - Method in class org.apache.wayang.flink.plugin.FlinkBasicPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.flink.plugin.FlinkConversionPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcConversionsPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.giraph.plugin.GiraphPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.java.plugin.JavaBasicPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.java.plugin.JavaChannelConversionPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.java.plugin.JavaGraphPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.postgres.plugin.PostgresConversionsPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.postgres.plugin.PostgresPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.spark.plugin.SparkBasicPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.spark.plugin.SparkConversionPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.spark.plugin.SparkGraphPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.spark.plugin.SparkMLPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3ConversionPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3Plugin
- getRequiredPlatforms() - Method in class org.apache.wayang.tensorflow.plugin.TensorflowConversionPlugin
- getRequiredPlatforms() - Method in class org.apache.wayang.tensorflow.plugin.TensorflowPlugin
- getResourceInfo() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the resource information of this executor.
- getResourceInfo() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getResourceInfo() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getResourceInfo() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getResourceURL(String) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Provides a resource as
URL
. - getResourceUtilization() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- getResultSerializationTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Returns the time taken to serialize the result of the task.
- getResultSerializationTime() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getResultSize() - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Gets the size of the result produced by the task.
- getResultSize() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- getRootParent() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Get the top-level parent containing this instance.
- getRounds() - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
- getRowCount() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableStatistic
- getRowID() - Method in class org.apache.wayang.iejoin.data.Data
- getRowType(RelDataTypeFactory) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- getRowType(RelDataTypeFactory) - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTable
- getRuleIndex() - Method in class org.apache.wayang.core.mathex.MathExParser.ExpressionContext
- getRuleNames() - Method in class org.apache.wayang.core.mathex.MathExLexer
- getRuleNames() - Method in class org.apache.wayang.core.mathex.MathExParser
- getSampleMethod() - Method in class org.apache.wayang.basic.operators.SampleOperator
- getSampleSize(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.basic.operators.SampleOperator
-
Retrieve the sample size for this instance w.r.t. the current iteration.
- getSchema() - Method in class org.apache.wayang.basic.operators.ParquetSource
- getSchema(Configuration) - Static method in class org.apache.wayang.api.sql.calcite.schema.SchemaUtils
- getSchemaDelimiter(String) - Method in class org.apache.wayang.api.sql.calcite.utils.ModelParser
-
Fetches the column delimiter character of the provided schema
- getSchemaName() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangSchema
- getScope() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
- getSeed(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.basic.operators.SampleOperator
-
Retrieve the seed for this instance w.r.t. the current iteration.
- getSelectionProbability(double, double, double) - Static method in class org.apache.wayang.profiler.log.GeneticOptimizer
- getSelectivity() - Method in class org.apache.wayang.core.function.ConsumerDescriptor
-
Get the selectivity of this instance.
- getSelectivity() - Method in class org.apache.wayang.core.function.FlatMapDescriptor
-
Get the selectivity of this instance.
- getSelectivity() - Method in class org.apache.wayang.core.function.MapPartitionsDescriptor
-
Get the selectivity of this instance.
- getSelectivity() - Method in class org.apache.wayang.core.function.PredicateDescriptor
-
Get the selectivity of this instance.
- getSelectivity(FunctionDescriptor) - Static method in class org.apache.wayang.core.function.FunctionDescriptor
-
Utility method to retrieve the selectivity of a
FunctionDescriptor
- getSerialization() - Method in class org.apache.wayang.basic.channels.FileChannel.Descriptor
- getSerializedATN() - Method in class org.apache.wayang.core.mathex.MathExLexer
- getSerializedATN() - Method in class org.apache.wayang.core.mathex.MathExParser
- getServingOutputSlots() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
- getShape() - Method in class org.apache.wayang.basic.model.op.Input
- getShape() - Method in class org.apache.wayang.basic.model.op.Reshape
- getSiblings() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- getSimpleClassName() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getSingle(Collection<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Validate that there is only a single element in the
collection
and return it. - getSingleIterationImplementation() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
-
Originally, only a single
LoopImplementation.IterationImplementation
is supported by Wayang. - getSingleOrNull(Collection<T>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Validate that there is at most one element in the
collection
and return it (ornull
otherwise). - getSinglePath() - Method in class org.apache.wayang.basic.channels.FileChannel.Instance
-
If there is only a single element on
FileChannel.Instance.getPaths()
, retrieves it. - getSink() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- getSink() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Enter this container.
- getSink() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- getSinks() - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
- getSinkTasks() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow
- getSlotMapping() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- getSlotMapping() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Provide the
SlotMapping
that translates between the containedOperator
s and the containingCompositeOperator
as defined byOperatorContainer.toOperator()
. - getSlotMapping() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- getSocket() - Method in class org.apache.wayang.api.python.executor.PythonProcessCaller
- getSortOrders(IEJoinMasterOperator.JoinCondition, IEJoinMasterOperator.JoinCondition) - Static method in class org.apache.wayang.iejoin.operators.IEJoinMasterOperator
- getSource() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- getSource() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Enter this container.
- getSource() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- getSource() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.Link
- getSourceChannel() - Method in class org.apache.wayang.core.platform.Junction
- getSourceChannelDescriptor() - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
- getSourceOperator() - Method in class org.apache.wayang.core.platform.Junction
- getSourceOutput() - Method in class org.apache.wayang.core.platform.Junction
- getSparkContext(Job) - Method in class org.apache.wayang.spark.platform.SparkPlatform
-
Configures the single maintained
JavaSparkContext
according to thejob
and returns it. - getSparkUser() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Returns the user associated with the Spark application.
- getSparkUser() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- getSparkUser() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- getSqlImplementation() - Method in class org.apache.wayang.core.function.PredicateDescriptor
-
This function is not built to last.
- getSqlImplementation() - Method in class org.apache.wayang.core.function.TransformationDescriptor
-
This function is not built to last.
- getSqlQuery() - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Instance
- getSqlQueryChannelDescriptor() - Method in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
-
Retrieve a
SqlQueryChannel.Descriptor
for this instance. - getSquashedCostEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
-
Retrieve the squashed cost estimate for this instance.
- getSquashedCostEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
-
Retrieve the cost estimate for this instance.
- getSquashedCostEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Retrieves the cost estimate for this instance including any overhead.
- getSquashedCostEstimate() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Get the squashed estimated costs incurred by this instance (without fix costs).
- getSquashedCostEstimate(OptimizationContext) - Method in class org.apache.wayang.core.platform.Junction
-
Calculates the cost estimate for all
ExecutionOperator
s in this instance for a givenOptimizationContext
that should be known itself (or as a fork) to this instance. - getSquashedEstimate(PlanImplementation, boolean) - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
-
Retrieves the cost estimate for this instance.
- getSquashedEstimate(PlanImplementation, boolean) - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCost
-
Returns a squashed cost estimate.
- getSquashedParallelEstimate(PlanImplementation, boolean) - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
-
Retrieves the cost estimate for this instance taking into account parallel stage execution.
- getSquashedParallelEstimate(PlanImplementation, boolean) - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCost
- getStage() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- getStageAttempt() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the attempt ID of the stage.
- getStageAttempt() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getStageAttempt() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getStageAttempt() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getStageAttemptId() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the ID of the stage attempt.
- getStageAttemptId() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getStageAttemptId() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getStageAttemptId() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getStageID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the ID of the stage the executor is running.
- getStageID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Returns the stage ID associated with this job.
- getStageID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the ID of the stage to which this task belongs.
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getStageID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getStageName() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the name of this stage.
- getStageName() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getStageName() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getStageName() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getStages() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
Collects all
ExecutionStage
s in this instance. - getStages() - Method in class org.apache.wayang.core.plan.executionplan.PlatformExecution
- getStartingStages() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
- getStartOperators() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Find the
ExecutionOperator
that do not depend on any otherExecutionOperator
as input. - getStartTasks() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
All tasks with exclusively inbound input
Channel
s - getStartTime() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- getState() - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- getState() - Method in class org.apache.wayang.basic.operators.LoopOperator
- getState() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getState() - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
Optional operation.
- getStatistic() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTable
- getStatus() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the status of this stage.
- getStatus() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getStatus() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getStatus() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getStopWatch() - Method in class org.apache.wayang.core.api.Job
-
Provide the
StopWatch
that is used to instrument the execution of this instance. - getStorage() - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
To work with storage object provided to persist or load experiments
- getStorageContainer() - Method in class org.apache.wayang.basic.operators.AzureBlobStorageSource
- getStride() - Method in class org.apache.wayang.basic.model.op.nn.Conv
- getStride() - Method in class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- getString(int) - Method in class org.apache.wayang.basic.data.Record
-
Retrieve a field as a
String
. - getString(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- getStringProperty(String) - Method in class org.apache.wayang.core.api.Configuration
- getStringProperty(String, String) - Method in class org.apache.wayang.core.api.Configuration
- getSubject() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- getSubmissionTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the submission time of this stage.
- getSubmissionTime() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getSubmissionTime() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getSubmissionTime() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getSubprofiles() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- getSubSchema(String) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getSubSchemaNames() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getSuccessorIterationImplementation() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- getSuccessors() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- getSupportedInputChannels(int) - Method in class org.apache.wayang.api.sql.sources.fs.JavaCSVTableSource
- getSupportedInputChannels(int) - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCartesianOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCollectionSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCollectionSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCountOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkDistinctOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkFilterOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkGroupByOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkIntersectOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkJoinOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkLoopOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkMapOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkReduceByOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkRepeatOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkSampleOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkSortOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkTextFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkTextFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkTsvFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkUnionAllOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.genericjdbc.operators.GenericJdbcTableSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.iejoin.operators.JavaIEJoinOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.iejoin.operators.JavaIESelfJoinOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.iejoin.operators.SparkIEJoinOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.iejoin.operators.SparkIESelfJoinOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.graph.JavaPageRankOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaAmazonS3Source
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaAzureBlobStorageSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCartesianOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCoGroupOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCollectionSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCollectOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCountOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaDistinctOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaDoWhileOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaFilterOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaFlatMapOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaGlobalReduceOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaGoogleCloudStorageSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaIntersectOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaJoinOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaLocalCallbackSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaLoopOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaMapOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaMapPartitionsOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaObjectFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaObjectFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaParquetSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaRandomSampleOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaReduceByOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaRepeatOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaReservoirSampleOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaSortOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTextFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTextFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTsvFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTsvFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.java.operators.JavaUnionAllOperator
- getSupportedInputChannels(int) - Method in interface org.apache.wayang.jdbc.operators.JdbcExecutionOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.jdbc.operators.SqlToRddOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.postgres.operators.PostgresTableSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkModelTransformOperator
-
Deprecated.
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkPredictOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkBroadcastOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCacheOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCartesianOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCoGroupOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCollectionSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCollectOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCountOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkDistinctOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkDoWhileOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkFilterOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkFlatMapOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkIntersectOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkJoinOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkLocalCallbackSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkLoopOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkMapOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkObjectFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkObjectFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkParquetSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkReduceByOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkRepeatOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkSortOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTextFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTextFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTsvFileSink
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTsvFileSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkUnionAllOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkZipWithIdOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.sqlite3.operators.Sqlite3TableSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowCollectionSource
- getSupportedInputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowCollectOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowDLTrainingOperator
- getSupportedInputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowPredictOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.api.sql.sources.fs.JavaCSVTableSource
- getSupportedOutputChannels(int) - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Deprecated.
ExecutionOperator
s should only support a singleChannelDescriptor
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCartesianOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCoGroupOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCollectionSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCollectionSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkCountOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkDistinctOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkDoWhileOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkFilterOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkFlatMapOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkGlobalMaterializedGroupOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkGlobalReduceOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkGroupByOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkIntersectOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkJoinOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkLocalCallbackSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkLoopOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkMapOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkMapPartitionsOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkMaterializedGroupByOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkReduceByOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkRepeatExpandedOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkRepeatOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkSampleOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkSortOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkTextFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkTextFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkTsvFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkUnionAllOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.flink.operators.FlinkZipWithIdOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.iejoin.operators.JavaIEJoinOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.iejoin.operators.JavaIESelfJoinOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.iejoin.operators.SparkIEJoinOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.iejoin.operators.SparkIESelfJoinOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.graph.JavaPageRankOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaAmazonS3Source
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaAzureBlobStorageSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCartesianOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCoGroupOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCollectionSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCollectOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaCountOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaDistinctOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaDoWhileOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaFilterOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaFlatMapOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaGlobalReduceOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaGoogleCloudStorageSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaIntersectOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaJoinOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaKafkaTopicSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaLocalCallbackSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaLoopOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaMapOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaMapPartitionsOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaObjectFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaObjectFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaParquetSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaRandomSampleOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaReduceByOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaRepeatOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaReservoirSampleOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaSortOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTextFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTextFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTsvFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaTsvFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.java.operators.JavaUnionAllOperator
- getSupportedOutputChannels(int) - Method in interface org.apache.wayang.jdbc.operators.JdbcExecutionOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.jdbc.operators.SqlToRddOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkModelTransformOperator
-
Deprecated.
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.ml.SparkPredictOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkBroadcastOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCacheOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCartesianOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCoGroupOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCollectionSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCollectOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkCountOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkDistinctOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkDoWhileOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkFilterOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkFlatMapOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkIntersectOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkJoinOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkLocalCallbackSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkLoopOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkMapOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkObjectFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkObjectFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkParquetSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkReduceByOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkRepeatOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkSortOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTextFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTextFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTsvFileSink
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkTsvFileSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkUnionAllOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.spark.operators.SparkZipWithIdOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowCollectionSource
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowCollectOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowDLTrainingOperator
- getSupportedOutputChannels(int) - Method in class org.apache.wayang.tensorflow.operators.TensorflowPredictOperator
- getTable(String) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getTableMap() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangSchema
- getTableName() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- getTableName() - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTable
- getTableName() - Method in class org.apache.wayang.basic.operators.TableSource
- getTableNames() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getTags() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- getTailTupleData() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- getTargetActivator() - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activation
- getTargetChannel(int) - Method in class org.apache.wayang.core.platform.Junction
- getTargetChannelDescriptor() - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
- getTargetChannels() - Method in class org.apache.wayang.core.platform.Junction
- getTargetInput(int) - Method in class org.apache.wayang.core.platform.Junction
- getTargetInputs() - Method in class org.apache.wayang.core.platform.Junction
- getTargetOperator(int) - Method in class org.apache.wayang.core.platform.Junction
- getTargetPlatforms() - Method in class org.apache.wayang.core.mapping.PlanTransformation
- getTargetPlatforms() - Method in class org.apache.wayang.core.mapping.SubplanMatch
- getTargetPlatforms() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Tells if this instance should be executed/implemented only on a certain set of
Platform
s. - getTargetPlatforms() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- getTaskID() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the ID of this task.
- getTaskID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getTaskID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getTaskID() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getTaskMetric() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Gets the task metric associated with this stage.
- getTaskMetric() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the
TaskMetric
associated with this task. - getTaskMetric() - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- getTaskMetric() - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- getTaskMetric() - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- getTaskMetric() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getTaskMetric() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getTaskMetric() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getTaskSatus() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the status of this task.
- getTaskSatus() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getTaskSatus() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getTaskSatus() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getTaskStatus() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the status of this task.
- getTaskStatus() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getTaskStatus() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getTaskStatus() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getTaskStatusForRunning() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Returns the current task status for running.
- getTaskStatusForRunning() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- getTaskStatusForRunning() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- getTaskStatusForRunning() - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- getTemplateKey() - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Retrieve the
Configuration
template key if any. - getTemplateKeys() - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Retrieve the
Configuration
template keys for this and all nested instances. - getTensorflowContext(Job) - Method in class org.apache.wayang.tensorflow.platform.TensorflowPlatform
- getTerminalTasks() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler
- getTerminalTasks() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
All tasks with exclusively outbound output
Channel
s - getTime() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Returns the start time of the application.
- getTime() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- getTime() - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- getTimeEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
-
Retrieve the
TimeEstimate
for this instance. - getTimeEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
-
Retrieve the
TimeEstimate
for this instance. - getTimeEstimate() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Retrieves the
TimeEstimate
for this instance, including platform overhead. - getTimeEstimate() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- getTimeEstimate(boolean) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Retrieves the
TimeEstimate
for this instance, including platform overhead. - getTimeEstimate(OptimizationContext) - Method in class org.apache.wayang.core.platform.Junction
-
Calculates the
TimeEstimate
for allExecutionOperator
s in this instance for a givenOptimizationContext
that should be known itself (or as a fork) to this instance. - getTimeToCostConverterProvider() - Method in class org.apache.wayang.core.api.Configuration
- getTokenNames() - Method in class org.apache.wayang.core.mathex.MathExLexer
-
Deprecated.
- getTokenNames() - Method in class org.apache.wayang.core.mathex.MathExParser
-
Deprecated.
- getTopicName() - Method in class org.apache.wayang.basic.operators.KafkaTopicSource
- getTotalCores() - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Returns the total number of cores available to this executor.
- getTotalCores() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- getTotalCores() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- getTotalCores() - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- getTraitDef() - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- getTransformations() - Method in class org.apache.wayang.basic.mapping.GlobalReduceMapping
- getTransformations() - Method in class org.apache.wayang.basic.mapping.MaterializedGroupByMapping
- getTransformations() - Method in class org.apache.wayang.basic.mapping.PageRankMapping
- getTransformations() - Method in class org.apache.wayang.basic.mapping.ReduceByMapping
- getTransformations() - Method in class org.apache.wayang.basic.mapping.RepeatMapping
- getTransformations() - Method in interface org.apache.wayang.core.mapping.Mapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.CartesianMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.CoGroupMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.CollectionSourceMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.CountMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.DistinctMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.DoWhileMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.FilterMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.FlatMapMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.GlobalMaterializedGroupMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.GlobalReduceMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.GroupByMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.IntersectMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.JoinMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.LocalCallbackSinkMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.LoopMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.MapMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.MapPartitionsMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.MaterializedGroupByMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.ObjectFileSinkMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.ObjectFileSourceMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.PageRankMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.ReduceByMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.RepeatMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.SampleMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.SortMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.TextFileSinkMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.TextFileSourceMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.UnionAllMapping
- getTransformations() - Method in class org.apache.wayang.flink.mapping.ZipWithIdMapping
- getTransformations() - Method in class org.apache.wayang.genericjdbc.mapping.FilterMapping
- getTransformations() - Method in class org.apache.wayang.genericjdbc.mapping.ProjectionMapping
- getTransformations() - Method in class org.apache.wayang.giraph.mappings.PageRankMapping
- getTransformations() - Method in class org.apache.wayang.iejoin.mapping.java.IEJoinMapping
- getTransformations() - Method in class org.apache.wayang.iejoin.mapping.java.IESelfJoinMapping
- getTransformations() - Method in class org.apache.wayang.iejoin.mapping.spark.IEJoinMapping
- getTransformations() - Method in class org.apache.wayang.iejoin.mapping.spark.IESelfJoinMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.AmazonS3SourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.AzureBlobStorageSourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.CartesianMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.CoGroupMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.CollectionSourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.CountMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.DistinctMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.DoWhileMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.FilterMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.FlatMapMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.GlobalMaterializedGroupMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.GlobalReduceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.GoogleCloudStorageSourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.graph.PageRankMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.IntersectMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.JoinMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.KafkaTopicSinkMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.KafkaTopicSourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.LocalCallbackSinkMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.LoopMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.MapMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.MapPartitionsMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.MaterializedGroupByMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.ObjectFileSinkMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.ObjectFileSourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.ParquetSourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.ReduceByMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.RepeatMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.SampleMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.SortMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.TextFileSinkMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.TextFileSourceMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.UnionAllMapping
- getTransformations() - Method in class org.apache.wayang.java.mapping.ZipWithIdMapping
- getTransformations() - Method in class org.apache.wayang.postgres.mapping.FilterMapping
- getTransformations() - Method in class org.apache.wayang.postgres.mapping.JoinMapping
- getTransformations() - Method in class org.apache.wayang.postgres.mapping.ProjectionMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.CartesianMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.CoGroupMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.CollectionSourceMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.CountMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.DistinctMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.DoWhileMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.FilterMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.FlatMapMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.GlobalMaterializedGroupMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.GlobalReduceMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.graph.PageRankMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.IntersectMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.JoinMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.KafkaTopicSinkMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.KafkaTopicSourceMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.LocalCallbackSinkMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.LoopMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.MapMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.MapPartitionsMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.MaterializedGroupByMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.DecisionTreeClassificationMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.DecisionTreeRegressionMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.KMeansMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.LinearRegressionMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.LinearSVCMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.LogisticRegressionMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.ModelTransformMapping
-
Deprecated.
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ml.PredictMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ObjectFileSinkMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ObjectFileSourceMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ParquetSourceMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ReduceByMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.RepeatMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.SampleMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.SortMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.TextFileSinkMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.TextFileSourceMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.UnionAllMapping
- getTransformations() - Method in class org.apache.wayang.spark.mapping.ZipWithIdMapping
- getTransformations() - Method in class org.apache.wayang.sqlite3.mapping.FilterMapping
- getTransformations() - Method in class org.apache.wayang.sqlite3.mapping.ProjectionMapping
- getTransformations() - Method in class org.apache.wayang.tensorflow.mapping.CollectionSourceMapping
- getTransformations() - Method in class org.apache.wayang.tensorflow.mapping.DLTrainingOperatorMapping
- getTransformations() - Method in class org.apache.wayang.tensorflow.mapping.PredictMapping
- getTraversedNodes() - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Retrieve all traversed operators.
- getTraversedNodesWith(Predicate<Operator>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Retrieve all traversed operators that fulfill a predicate.
- getType() - Method in class org.apache.wayang.basic.operators.FilterOperator
- getType() - Method in class org.apache.wayang.basic.operators.GlobalReduceOperator
- getType() - Method in class org.apache.wayang.basic.operators.IntersectOperator
-
Provides the type of input and output datasets.
- getType() - Method in class org.apache.wayang.basic.operators.ReduceByOperator
- getType() - Method in class org.apache.wayang.basic.operators.RepeatOperator
- getType() - Method in class org.apache.wayang.basic.operators.SampleOperator
- getType() - Method in class org.apache.wayang.commons.util.profiledb.model.Measurement
- getType() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- getType() - Method in class org.apache.wayang.core.plan.wayangplan.UnarySink
- getType() - Method in class org.apache.wayang.core.plan.wayangplan.UnarySource
- getType() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.ChannelNode
- getType() - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- getType() - Method in class org.apache.wayang.spark.operators.SparkBroadcastOperator
- getType(String) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getTypeClass() - Method in class org.apache.wayang.basic.operators.ObjectFileSource
- getTypeClass() - Method in class org.apache.wayang.core.types.BasicDataUnitType
- getTypeClass() - Method in class org.apache.wayang.core.types.DataUnitGroupType
- getTypeClass() - Method in class org.apache.wayang.core.types.DataUnitType
- getTypeName(Class<? extends Measurement>) - Static method in class org.apache.wayang.commons.util.profiledb.model.Measurement
-
Returns implementation Class of this Measurement
- getTypeNames() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getTypeParameters(Class<?>, Class<?>) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Retrieve the
Type
s of type parameters from an extended/implemented superclass/interface. - getTypes() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- getUdfJarPaths() - Method in class org.apache.wayang.core.api.Job
- getUdfSelectivityProvider() - Method in class org.apache.wayang.core.api.Configuration
- getUpperCost() - Method in class org.apache.wayang.core.profiling.CostMeasurement
- getUpperEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- getUpperEstimate() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- getUpstreamMapping() - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
-
Retrieves the upstream mapping of
Slot
s. - getUtilizedPlatforms() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Retrieve the
Platform
s that are utilized by this instance. - getValue() - Method in class org.apache.wayang.core.util.mathex.model.Constant
- getValue() - Method in class org.apache.wayang.core.util.Optional
- getValue() - Method in class org.apache.wayang.iejoin.data.Data
- getValue(Individual) - Method in class org.apache.wayang.profiler.log.Variable
- getValues() - Method in class org.apache.wayang.basic.data.Record
- getValues() - Method in class org.apache.wayang.ml4all.utils.SparseVector
- getVariable(int) - Method in class org.apache.wayang.profiler.log.OptimizationSpace
- getVariable(String) - Method in interface org.apache.wayang.core.util.mathex.Context
-
Provide the value for a variable.
- getVariable(String) - Method in class org.apache.wayang.core.util.mathex.DefaultContext
- getVariable(String) - Method in class org.apache.wayang.profiler.log.OptimizationSpace
- getVariables() - Method in class org.apache.wayang.profiler.log.OptimizationSpace
- getVocabulary() - Method in class org.apache.wayang.core.mathex.MathExLexer
- getVocabulary() - Method in class org.apache.wayang.core.mathex.MathExParser
- getWayangFunction() - Method in class org.apache.wayang.spark.compiler.FunctionCompiler.KeyExtractor
- getWayangFunction() - Method in class org.apache.wayang.spark.compiler.FunctionCompiler.Reducer
- getWayangFunction() - Method in interface org.apache.wayang.spark.compiler.FunctionCompiler.WayangSparkFunction
- getWayangPlan() - Method in class org.apache.wayang.core.api.Job
-
Provide the
WayangPlan
executed by this instance. - getWrapperClass(Type, int) - Static method in class org.apache.wayang.core.util.ReflectionUtils
- getWriteMode() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- Giraph - Class in org.apache.wayang.giraph
-
Register for relevant components of this module.
- Giraph() - Constructor for class org.apache.wayang.giraph.Giraph
- GiraphExecutionOperator - Interface in org.apache.wayang.giraph.operators
-
ExecutionOperator
that can be run by theGiraphExecutor
. - GiraphExecutor - Class in org.apache.wayang.giraph.execution
-
Executor
for theGiraphPlatform
. - GiraphExecutor(GiraphPlatform, Job) - Constructor for class org.apache.wayang.giraph.execution.GiraphExecutor
- GiraphPageRankOperator - Class in org.apache.wayang.giraph.operators
-
PageRank
Operator
implementation for theGiraphPlatform
. - GiraphPageRankOperator(Integer) - Constructor for class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- GiraphPageRankOperator(PageRankOperator) - Constructor for class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- GiraphPlatform - Class in org.apache.wayang.giraph.platform
-
Giraph
Platform
for Wayang. - GiraphPlatform() - Constructor for class org.apache.wayang.giraph.platform.GiraphPlatform
- GiraphPlugin - Class in org.apache.wayang.giraph.plugin
-
This
Plugin
activates default capabilities of theGiraphPlatform
. - GiraphPlugin() - Constructor for class org.apache.wayang.giraph.plugin.GiraphPlugin
- GlobalMaterializedGroupMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
GlobalMaterializedGroupOperator
toFlinkGlobalMaterializedGroupOperator
. - GlobalMaterializedGroupMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
GlobalMaterializedGroupOperator
toJavaGlobalMaterializedGroupOperator
. - GlobalMaterializedGroupMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
GlobalMaterializedGroupOperator
toSparkGlobalMaterializedGroupOperator
. - GlobalMaterializedGroupMapping() - Constructor for class org.apache.wayang.flink.mapping.GlobalMaterializedGroupMapping
- GlobalMaterializedGroupMapping() - Constructor for class org.apache.wayang.java.mapping.GlobalMaterializedGroupMapping
- GlobalMaterializedGroupMapping() - Constructor for class org.apache.wayang.spark.mapping.GlobalMaterializedGroupMapping
- GlobalMaterializedGroupOperator<Type> - Class in org.apache.wayang.basic.operators
-
This operator groups the elements of a data set into a single data quantum.
- GlobalMaterializedGroupOperator(Class<Type>) - Constructor for class org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator
-
Creates a new instance.
- GlobalMaterializedGroupOperator(GlobalMaterializedGroupOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator
-
Copies an instance (exclusive of broadcasts).
- GlobalMaterializedGroupOperator(DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator
-
Creates a new instance.
- GlobalReduceMapping - Class in org.apache.wayang.basic.mapping
-
This mapping detects combinations of the
GroupByOperator
andReduceOperator
and merges them into a singleReduceByOperator
. - GlobalReduceMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
GlobalReduceOperator
toFlinkGlobalReduceOperator
. - GlobalReduceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
GlobalReduceOperator
toJavaGlobalReduceOperator
. - GlobalReduceMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
GlobalReduceOperator
toSparkGlobalReduceOperator
. - GlobalReduceMapping() - Constructor for class org.apache.wayang.basic.mapping.GlobalReduceMapping
- GlobalReduceMapping() - Constructor for class org.apache.wayang.flink.mapping.GlobalReduceMapping
- GlobalReduceMapping() - Constructor for class org.apache.wayang.java.mapping.GlobalReduceMapping
- GlobalReduceMapping() - Constructor for class org.apache.wayang.spark.mapping.GlobalReduceMapping
- GlobalReduceOperator<Type> - Class in org.apache.wayang.basic.operators
-
This operator groups the elements of a data set and aggregates the groups.
- GlobalReduceOperator(GlobalReduceOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.GlobalReduceOperator
-
Copies an instance (exclusive of broadcasts).
- GlobalReduceOperator(FunctionDescriptor.SerializableBinaryOperator<Type>, Class<Type>) - Constructor for class org.apache.wayang.basic.operators.GlobalReduceOperator
-
Creates a new instance.
- GlobalReduceOperator(ReduceDescriptor<Type>) - Constructor for class org.apache.wayang.basic.operators.GlobalReduceOperator
-
Creates a new instance.
- GlobalReduceOperator(ReduceDescriptor<Type>, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.GlobalReduceOperator
-
Creates a new instance.
- GoogleCloudStorageSource - Class in org.apache.wayang.basic.operators
- GoogleCloudStorageSource(String, String, String) - Constructor for class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- GoogleCloudStorageSource(String, String, String, String) - Constructor for class org.apache.wayang.basic.operators.GoogleCloudStorageSource
- GoogleCloudStorageSource(GoogleCloudStorageSource) - Constructor for class org.apache.wayang.basic.operators.GoogleCloudStorageSource
-
Copies an instance (exclusive of broadcasts).
- GoogleCloudStorageSource.CardinalityEstimator - Class in org.apache.wayang.basic.operators
-
Custom
CardinalityEstimator
forFlatMapOperator
s. - GoogleCloudStorageSourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
GoogleCloudStorageSource
toJavaGoogleClodStorageSource
. - GoogleCloudStorageSourceMapping() - Constructor for class org.apache.wayang.java.mapping.GoogleCloudStorageSourceMapping
- GradientDescent - Class in org.apache.wayang.basic.model.optimizer
- GradientDescent(float) - Constructor for class org.apache.wayang.basic.model.optimizer.GradientDescent
- GradientDescent(float, String) - Constructor for class org.apache.wayang.basic.model.optimizer.GradientDescent
- GRAPH_MAPPINGS - Static variable in class org.apache.wayang.basic.mapping.Mappings
- GRAPH_MAPPINGS - Static variable in class org.apache.wayang.java.mapping.Mappings
- GRAPH_MAPPINGS - Static variable in class org.apache.wayang.spark.mapping.Mappings
- graphDensity - Variable in class org.apache.wayang.basic.operators.PageRankOperator
- graphPlugin() - Static method in class org.apache.wayang.basic.WayangBasics
- graphPlugin() - Static method in class org.apache.wayang.flink.Flink
-
Retrieve the
FlinkGraphPlugin
. - graphPlugin() - Static method in class org.apache.wayang.java.Java
-
Retrieve the
JavaGraphPlugin
. - graphPlugin() - Static method in class org.apache.wayang.spark.Spark
-
Retrieve the
SparkGraphPlugin
. - GreaterThan - Enum constant in enum class org.apache.wayang.iejoin.operators.IEJoinMasterOperator.JoinCondition
- GreaterThanEqual - Enum constant in enum class org.apache.wayang.iejoin.operators.IEJoinMasterOperator.JoinCondition
- Grep - Class in org.apache.wayang.apps.grep
- Grep() - Constructor for class org.apache.wayang.apps.grep.Grep
- GroupByMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
GroupByOperator
toFlinkGroupByOperator
. - GroupByMapping() - Constructor for class org.apache.wayang.flink.mapping.GroupByMapping
- GroupByOperator<Input,
Key> - Class in org.apache.wayang.basic.operators -
This is the auxiliary GroupBy operator, i.e., it behaves differently depending on its context.
- GroupByOperator(GroupByOperator<Input, Key>) - Constructor for class org.apache.wayang.basic.operators.GroupByOperator
- GroupByOperator(FunctionDescriptor.SerializableFunction<Input, Key>, Class<Input>, Class<Key>) - Constructor for class org.apache.wayang.basic.operators.GroupByOperator
-
Creates a new instance.
- GroupByOperator(TransformationDescriptor<Input, Key>) - Constructor for class org.apache.wayang.basic.operators.GroupByOperator
-
Creates a new instance.
- GroupByOperator(TransformationDescriptor<Input, Key>, DataSetType<Input>, DataSetType<Iterable<Input>>) - Constructor for class org.apache.wayang.basic.operators.GroupByOperator
-
Creates a new instance.
- GROUPED_NONE - Static variable in class org.apache.wayang.core.types.DataSetType
-
Stands for the absence of an actual instance.
- groupedNone() - Static method in class org.apache.wayang.core.types.DataSetType
-
Returns a grouped null type.
- GroupKey - Class in org.apache.wayang.apps.tpch.data.q1
-
Grouping key used in Query 1.
- GroupKey() - Constructor for class org.apache.wayang.apps.tpch.data.q1.GroupKey
- GroupKey(char, char) - Constructor for class org.apache.wayang.apps.tpch.data.q1.GroupKey
- GsonSerializer() - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorBase.GsonSerializer
H
- HadoopFileSystem - Class in org.apache.wayang.core.util.fs
-
FileSystem
immplementation for the HDFS. - HadoopFileSystem() - Constructor for class org.apache.wayang.core.util.fs.HadoopFileSystem
- has(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- hasElement(PageRankParameters.PageRankEnum) - Static method in class org.apache.wayang.giraph.Algorithm.PageRankParameters
- hashCode() - Method in class org.apache.wayang.apps.tpch.data.q1.GroupKey
- hashCode() - Method in class org.apache.wayang.basic.channels.FileChannel.Descriptor
- hashCode() - Method in class org.apache.wayang.basic.data.Record
- hashCode() - Method in class org.apache.wayang.basic.data.Tuple2
- hashCode() - Method in class org.apache.wayang.basic.data.Tuple5
- hashCode() - Method in class org.apache.wayang.basic.types.RecordType
- hashCode() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- hashCode() - Method in class org.apache.wayang.commons.util.profiledb.model.Measurement
- hashCode() - Method in class org.apache.wayang.commons.util.profiledb.model.Subject
- hashCode() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- hashCode() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- hashCode() - Method in class org.apache.wayang.core.platform.ChannelDescriptor
- hashCode() - Method in class org.apache.wayang.core.types.BasicDataUnitType
- hashCode() - Method in class org.apache.wayang.core.types.DataSetType
- hashCode() - Method in class org.apache.wayang.core.types.DataUnitGroupType
- hashCode() - Method in class org.apache.wayang.core.util.Bitmask
- hashCode() - Method in class org.apache.wayang.core.util.Canonicalizer
- hashCode() - Method in class org.apache.wayang.core.util.Counter
- hashCode() - Method in class org.apache.wayang.core.util.Tuple
- hashCode() - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Descriptor
- hasNext() - Method in class org.apache.wayang.api.python.executor.ReaderIterator
- hasNext() - Method in class org.apache.wayang.flink.operators.CollectionSplittableIterator
- hasNext() - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator.ResultSetIterator
- hasSample() - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- HDFS_MS_PER_MB_PROPERTY - Static variable in class org.apache.wayang.giraph.platform.GiraphPlatform
- HDFS_OBJECT_FILE_DESCRIPTOR - Static variable in class org.apache.wayang.basic.channels.FileChannel
- HDFS_OBJECT_FILE_TO_STREAM - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- HDFS_OBJECT_FILE_TO_UNCACHED_RDD - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- HDFS_TSV_DESCRIPTOR - Static variable in class org.apache.wayang.basic.channels.FileChannel
- HDFS_TSV_TO_STREAM - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- HDFS_TSV_TO_UNCACHED_RDD - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- hostLoopContext - Variable in class org.apache.wayang.core.optimizer.OptimizationContext
-
The instance in that this instance is nested - or
null
if it is top-level. - HttpMonitor - Class in org.apache.wayang.core.monitor
-
TODO: Implement
- HttpMonitor() - Constructor for class org.apache.wayang.core.monitor.HttpMonitor
I
- id - Variable in class org.apache.wayang.basic.model.op.Op
- IDENTIFIER - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- IDENTIFIER - Static variable in class org.apache.wayang.core.mathex.MathExParser
- IDENTIFIER() - Method in class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- IDENTIFIER() - Method in class org.apache.wayang.core.mathex.MathExParser.VariableContext
- IEJoin - Class in org.apache.wayang.iejoin
- IEJoin() - Constructor for class org.apache.wayang.iejoin.IEJoin
- IEJoinMapping - Class in org.apache.wayang.iejoin.mapping.java
-
Mapping from
IEJoinOperator
toJavaIEJoinOperator
. - IEJoinMapping - Class in org.apache.wayang.iejoin.mapping.spark
-
Mapping from
IEJoinOperator
toSparkIEJoinOperator
. - IEJoinMapping() - Constructor for class org.apache.wayang.iejoin.mapping.java.IEJoinMapping
- IEJoinMapping() - Constructor for class org.apache.wayang.iejoin.mapping.spark.IEJoinMapping
- IEJoinMasterOperator - Class in org.apache.wayang.iejoin.operators
-
This operator decides the correct sorting orders for IEJoin
- IEJoinMasterOperator() - Constructor for class org.apache.wayang.iejoin.operators.IEJoinMasterOperator
- IEJoinMasterOperator.JoinCondition - Enum Class in org.apache.wayang.iejoin.operators
-
Created by khayyzy on 5/19/16.
- IEJoinOperator<Type0,
Type1, Input> - Class in org.apache.wayang.iejoin.operators -
This operator applies inequality join on elements of input datasets.
- IEJoinOperator(Class<Input>, Class<Input>, TransformationDescriptor<Input, Type0>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.IEJoinOperator
- IEJoinOperator(DataSetType<Input>, DataSetType<Input>, TransformationDescriptor<Input, Type0>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.IEJoinOperator
- IESelfJoinMapping - Class in org.apache.wayang.iejoin.mapping.java
-
Mapping from
IESelfJoinOperator
toJavaIESelfJoinOperator
. - IESelfJoinMapping - Class in org.apache.wayang.iejoin.mapping.spark
-
Mapping from
IESelfJoinOperator
toSparkIESelfJoinOperator
. - IESelfJoinMapping() - Constructor for class org.apache.wayang.iejoin.mapping.java.IESelfJoinMapping
- IESelfJoinMapping() - Constructor for class org.apache.wayang.iejoin.mapping.spark.IESelfJoinMapping
- IESelfJoinOperator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input> - Class in org.apache.wayang.iejoin.operators -
This operator applies inequality self join on elements of input datasets.
- IESelfJoinOperator(Class<Input>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- IESelfJoinOperator(DataSetType<Input>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- ifPresent(Object, Class<? super T>, Consumer<T>) - Static method in class org.apache.wayang.core.plugin.DynamicPlugin
-
Checks and casts the given
Object
. - impl - Variable in class org.apache.wayang.flink.compiler.KeySelectorFunction
- inChannels - Variable in class org.apache.wayang.basic.model.op.nn.Conv
- increaseBy(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Increases the
CardinalityEstimate
,TimeEstimate
, andcost estimate
of this instance by those of the given instance. - increment(T) - Method in class org.apache.wayang.core.util.Counter
- INDENT - Static variable in class org.apache.wayang.core.util.ExplainUtils
- index - Variable in class org.apache.wayang.core.plan.wayangplan.Slot
-
Lazy initialized. The index of this instance within its
Slot.owner
. - Individual - Class in org.apache.wayang.profiler.log
-
Context for the optimization of
LoadProfileEstimator
s. - inference(Operand<T>, List<Operand<?>>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm2D
- initConsumer(KafkaTopicSource) - Method in class org.apache.wayang.basic.operators.KafkaTopicSource
- initDefaultsFromConfiguration(Configuration) - Static method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
-
Initialize defaults for output format.
- INITIAL_CONVERGENCE_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.LoopOperator
- INITIAL_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.DoWhileOperator
- INITIAL_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.LoopOperator
- INITIAL_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.RepeatOperator
- initialExecutionPlan - Variable in class org.apache.wayang.core.monitor.Monitor
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.api.LogicalOperator
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.AssignWrapper
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.AssignWrapperLocal
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.ComputePerPartitionWrapper
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.ComputeWrapper
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapper
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapperWithModel
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LoopCheckWrapper
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LoopConvergenceWrapper
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.UpdateLocalWrapper
- initialise() - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.UpdateWrapper
- INITIALIZATION_MS_CONFIG_KEY - Static variable in class org.apache.wayang.flink.platform.FlinkPlatform
- INITIALIZATION_MS_CONFIG_KEY - Static variable in class org.apache.wayang.spark.platform.SparkPlatform
- initialize() - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankMasterCompute
- initialize(Configuration, String, List<Map>) - Method in class org.apache.wayang.core.monitor.DisabledMonitor
- initialize(Configuration, String, List<Map>) - Method in class org.apache.wayang.core.monitor.FileMonitor
- initialize(Configuration, String, List<Map>) - Method in class org.apache.wayang.core.monitor.HttpMonitor
- initialize(Configuration, String, List<Map>) - Method in class org.apache.wayang.core.monitor.Monitor
- initialize(Configuration, String, List<Map>) - Method in class org.apache.wayang.core.monitor.ZeroMQMonitor
- initialize(Operator, int) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- initialize(Operator, int) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- initialize(Operator, int, Operator, int) - Method in class org.apache.wayang.basic.operators.LoopOperator
- initialize(Operator, Operator) - Method in class org.apache.wayang.basic.operators.LoopOperator
- initializeGlobal(int) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
-
Initialization of the distributed file system if it is used.
- initializeOutputChannel(int, Configuration) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- initProducer(KafkaTopicSink<T>) - Method in class org.apache.wayang.basic.operators.KafkaTopicSink
- Input - Class in org.apache.wayang.basic.model.op
- Input(int[]) - Constructor for class org.apache.wayang.basic.model.op.Input
- Input(int[], String) - Constructor for class org.apache.wayang.basic.model.op.Input
- Input(int[], String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Input
- Input(int[], Input.Type) - Constructor for class org.apache.wayang.basic.model.op.Input
- Input(int[], Input.Type, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Input
- Input(int[], Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Input
- Input.Type - Enum Class in org.apache.wayang.basic.model.op
- inputCardinalities - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- InputSlot<T> - Class in org.apache.wayang.core.plan.wayangplan
-
An input slot declares an input of an
Operator
. - InputSlot() - Constructor for class org.apache.wayang.core.plan.wayangplan.InputSlot
- InputSlot(String, Operator, boolean, DataSetType<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Creates a new instance.
- InputSlot(String, Operator, DataSetType<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Creates a new, non-broadcast instance.
- InputSlot(InputSlot<T>, Operator) - Constructor for class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Creates a new instance that imitates the given
blueprint
, but for a differentowner
. - InputSlot(Slot<T>, Operator) - Constructor for class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Creates a new instance that imitates the given
blueprint
, but for a differentowner
. - inputSlots - Variable in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.ArgMax
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Cast
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Eq
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Get
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Input
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Mean
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.BatchNorm
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.Conv
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.ConvLSTM2D
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.CrossEntropyLoss
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.Linear
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.MSELoss
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.ReLU
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.Sigmoid
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.nn.Softmax
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Op
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Reshape
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Slice
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.Transpose
- inputsRequired() - Method in class org.apache.wayang.basic.model.op.ZeroLike
- inputType - Variable in class org.apache.wayang.core.function.ConsumerDescriptor
- inputType - Variable in class org.apache.wayang.core.function.FlatMapDescriptor
- inputType - Variable in class org.apache.wayang.core.function.MapPartitionsDescriptor
- inputType - Variable in class org.apache.wayang.core.function.PredicateDescriptor
- inputType - Variable in class org.apache.wayang.core.function.TransformationDescriptor
- inputTypeClass - Variable in class org.apache.wayang.flink.compiler.criterion.DummyFilter
- inputTypeClass - Variable in class org.apache.wayang.flink.compiler.criterion.DummyMap
- Instance(OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.basic.channels.FileChannel.Instance
-
Creates a new instance.
- Instance(Executor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.java.channels.CollectionChannel.Instance
- Instance(Executor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.java.channels.StreamChannel.Instance
- Instance(Executor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.jdbc.channels.SqlQueryChannel.Instance
-
Creates a new instance and registers it with its
Executor
. - Instance(FlinkExecutor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.flink.channels.DataSetChannel.Instance
- Instance(SparkExecutor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.spark.channels.BroadcastChannel.Instance
- Instance(SparkExecutor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.spark.channels.RddChannel.Instance
- Instance(TensorflowExecutor, OptimizationContext.OperatorContext, int) - Constructor for class org.apache.wayang.tensorflow.channels.TensorChannel.Instance
- INSTANCE - Enum constant in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- INSTANCE - Static variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema.Factory
- instantiateDefault(Class<? extends T>) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Creates a new instance of the given
Class
via the default constructor. - instantiateDefault(String) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Creates a new instance of a
Class
via the default constructor. - instantiateSomehow(Class<T>, List<Tuple<Class<?>, Supplier<?>>>) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Tries to instantiate an arbitrary instance of the given
Class
. - instantiateSomehow(Class<T>, Tuple<Class<?>, Supplier<?>>...) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Tries to instantiate an arbitrary instance of the given
Class
. - InstrumentationStrategy - Interface in org.apache.wayang.core.profiling
-
Determines, which
Channel
s in anExecutionPlan
should be instrumented. - INT16 - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
- INT32 - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
- INT64 - Enum constant in enum class org.apache.wayang.basic.model.op.Op.DType
- IntersectMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
IntersectOperator
toFlinkIntersectOperator
. - IntersectMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
IntersectOperator
toJavaIntersectOperator
. - IntersectMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
IntersectOperator
toSparkIntersectOperator
. - IntersectMapping() - Constructor for class org.apache.wayang.flink.mapping.IntersectMapping
- IntersectMapping() - Constructor for class org.apache.wayang.java.mapping.IntersectMapping
- IntersectMapping() - Constructor for class org.apache.wayang.spark.mapping.IntersectMapping
- IntersectOperator<Type> - Class in org.apache.wayang.basic.operators
-
This operator returns the set intersection of elements of input datasets.
- IntersectOperator(Class<Type>) - Constructor for class org.apache.wayang.basic.operators.IntersectOperator
- IntersectOperator(IntersectOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.IntersectOperator
-
Copies an instance (exclusive of broadcasts).
- IntersectOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.IntersectOperator
- IntervalLoadEstimator - Class in org.apache.wayang.core.optimizer.costs
-
Implementation of
LoadEstimator
that uses a interval-based cost function. - IntervalLoadEstimator(int, int, double, ToLongBiFunction<long[], long[]>, ToLongBiFunction<long[], long[]>) - Constructor for class org.apache.wayang.core.optimizer.costs.IntervalLoadEstimator
- IntervalLoadEstimator(int, int, double, CardinalityEstimate, ToLongBiFunction<long[], long[]>, ToLongBiFunction<long[], long[]>) - Constructor for class org.apache.wayang.core.optimizer.costs.IntervalLoadEstimator
- isActivationComplete() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlowCompiler.Activator
- isActivationComplete() - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activator
- isAlternative() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isAuxiliary() - Method in interface org.apache.wayang.core.plan.wayangplan.ElementaryOperator
-
Tells whether this instance is auxiliary, i.e., it support some non-auxiliary operators.
- isAuxiliary() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- isAvailable() - Method in class org.apache.wayang.core.util.Optional
- isBetweenStages() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Tests for inter-stage instances.
- isBroadcast() - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- isCompatibleWith(Slot<?>) - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- isComplete() - Method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow
- isConverged(int, WayangListValue) - Method in class org.apache.wayang.flink.compiler.criterion.WayangConvergenceCriterion
- isConversion() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isConversion() - Method in class org.apache.wayang.flink.operators.FlinkCollectionSink
- isConversion() - Method in class org.apache.wayang.flink.operators.FlinkCollectionSource
- isConversion() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSink
- isConversion() - Method in class org.apache.wayang.flink.operators.FlinkObjectFileSource
- isConversion() - Method in class org.apache.wayang.flink.operators.FlinkTsvFileSink
- isCopy() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Tells whether this instance is a copy.
- isDataSetSizeKnown() - Method in class org.apache.wayang.basic.operators.SampleOperator
-
Find out whether this instance knows about the size of the incoming dataset.
- isDirectory(String) - Method in interface org.apache.wayang.core.util.fs.FileSystem
- isDirectory(String) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- isDirectory(String) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- isDirectory(String) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- isDisjointFrom(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Checks whether all bits set in this instance are not set in the given instance.
- isDisposed() - Method in class org.apache.wayang.core.util.AbstractReferenceCountable
- isDisposed() - Method in interface org.apache.wayang.core.util.ReferenceCountable
-
Optional operation. Tell whether this instance has been disposed.
- isDisposed() - Method in class org.apache.wayang.flink.execution.FlinkContextReference
- isElementary() - Method in interface org.apache.wayang.core.plan.wayangplan.CompositeOperator
- isElementary() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isEmpty() - Method in class org.apache.wayang.core.util.Bitmask
-
Tells whether this instance is empty.
- isEmpty() - Method in class org.apache.wayang.core.util.Canonicalizer
- isEmpty() - Method in class org.apache.wayang.core.util.Counter
- isEmpty() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- isEmpty() - Method in class org.apache.wayang.ml4all.utils.SparseVector
- isEnabled(Configuration) - Static method in class org.apache.wayang.core.monitor.Monitor
- isExact() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
-
Checks whether this instance is an exact value, i.e., it is a confident single-point estimate.
- isExactly(long) - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
-
Checks whether this instance is an exact estimate of the given value.
- isExactly(long) - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
-
Checks whether this instance is an exact estimate of the given value.
- isExecutionBreaker() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Tells whether this instance connects different
PlatformExecution
s. - isExecutionOperator() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isFeedback() - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- isFeedbackInput(Channel) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
-
Determines whether the given input
Channel
implements a feedbackInputSlot
of the enclosedExecutionOperator
. - isFeedbackInput(InputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isFeedforward() - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
- isFeedforwardOutput(OutputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isFiltered(CardinalityEstimate, int, OptimizationContext) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
-
Determine whether this instance is suitable to handle the given conversion.
- isFiltered(CardinalityEstimate, int, OptimizationContext) - Method in class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- isFiltered(OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Tells whether this instance should not be executed on the face of the given
OptimizationContext.OperatorContext
. - isFinalIteration() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- isGroup() - Method in class org.apache.wayang.core.types.BasicDataUnitType
- isGroup() - Method in class org.apache.wayang.core.types.DataUnitGroupType
- isGroup() - Method in class org.apache.wayang.core.types.DataUnitType
-
Tells whether this data unit type represents groups of data units.
- isInFinishedLoop() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Tells whether this instance is in a
ExecutionStageLoop
that has finished iterating. - isInitialIteration() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- isInputMarked(int) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- isInputSlot() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- isJsonCompatible(Object) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Tells whether the given instance is a JSON datatype.
- isJsonNull(Object) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Tells whether the given instance is a (JSON)
null
value. - isKey(ImmutableBitSet) - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableStatistic
- isLoopHead() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
-
Determine if this instance is the loop head of its
ExecutionStageLoop
. - isLoopHead() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Identify this instance as the head of a loop.
- isLoopInvariant() - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Tells whether this instance is inside of a
LoopSubplan
and consumes anOutputSlot
outside of thatLoopSubplan
. - isLoopsIsolated() - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Tells whether potential loops within this instance have been isolated.
- isLoopSubplan() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isMarkedForInstrumentation() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- isMarkedForInstrumentation() - Method in interface org.apache.wayang.core.platform.ChannelInstance
-
Tells whether this instance should be instrumented
- isMutable() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- isNone() - Method in class org.apache.wayang.core.types.DataSetType
-
Find out whether this corresponds to either
DataSetType.none()
orDataSetType.groupedNone()
. - isolate(Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.LoopIsolator
-
Isolates the loop starting at the
allegedLoopHead
. - isolateLoops(WayangPlan) - Static method in class org.apache.wayang.core.plan.wayangplan.LoopIsolator
- isOutputMarked(int) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- isOutputSlot() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- isOverride() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- isOverride() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- isOwnerOf(Slot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isPivot() - Method in class org.apache.wayang.iejoin.data.Data
- isPlain() - Method in class org.apache.wayang.core.types.DataUnitType
-
Tells whether this is a normal data unit type.
- isReading(InputSlot<?>) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- isReading(InputSlot<?>) - Method in class org.apache.wayang.basic.operators.LoopOperator
- isReading(InputSlot<?>) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- isReading(InputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Tells whether the given
input
is read by this operator. - isReady() - Method in class org.apache.wayang.api.python.executor.PythonProcessCaller
- isRequestBreakpointFor(OutputSlot<?>, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.api.Job
-
Whether a
Breakpoint
is requested for the givenOutputSlot
. - isReusable() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Declares whether this is not a read-once instance.
- isReusable() - Method in class org.apache.wayang.core.platform.ChannelDescriptor
-
Declares whether this is not a read-once instance.
- isSane() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
Implements various sanity checks.
- isSane() - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Check that the given
WayangPlan
is as we expect it to be in the following steps. - isSinglePlatformExecutionPossible(ExecutionTask, Channel, ExecutionTask) - Method in class org.apache.wayang.core.platform.Platform
-
Tells whether the given constellation of producing and consuming
ExecutionTask
, linked by theChannel
can be handled within a singlePlatformExecution
of thisPlatform
- isSink() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Tells whether this operator is a sink, i.e., it has no outputs.
- isSink() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
- isSink() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- isSource() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Tells whether this operator is a source, i.e., it has no inputs.
- isSource() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Tells whether this instance represents a sink.
- isSource() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- isStartingStage() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- isSubmaskOf(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Checks whether all bits set in this instance are also set in the given instance.
- isSubplan() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isSuitableForBreakpoint() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Tells whether this instance lends itself for
Breakpoint
s. - isSuitableForBreakpoint() - Method in class org.apache.wayang.core.platform.ChannelDescriptor
-
Tells whether corresponding
Channel
s are suited to be betweenExecutionStage
s and fit withBreakpoint
s. - isSupertypeOf(BasicDataUnitType<?>) - Method in class org.apache.wayang.basic.types.RecordType
- isSupertypeOf(BasicDataUnitType<?>) - Method in class org.apache.wayang.core.types.DataUnitType
-
Checks whether the given instance is the same as this instance or more specific.
- isSupertypeOf(DataSetType) - Method in class org.apache.wayang.core.types.DataSetType
-
Checks whether this instance is more general that the given one, i.e., it is a valid type of datasets that are also valid under the given type.
- isSupportingBroadcastInputs() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- isSupportingBroadcastInputs() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- isTimeEstimatesComplete() - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- isTimeEstimatesComplete() - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
- isTimeEstimatesComplete() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- isTopLevel() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
-
Checks whether this instance is enumerating a top-level plan and is not a recursively invoked enumeration.
- isUnconnected() - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Checks whether this instance is not connected to any other instance via its
Slot
s. - isUnconvertedInstance(Object) - Static method in class org.apache.wayang.core.util.JsonSerializables
- isUpdateLocal() - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- isVetoingPlanChanges() - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
-
Allows to inhibit changes to the
ExecutionPlan
, such as on re-optimization. - iterables - Variable in class org.apache.wayang.core.util.CrossProductIterable
- ITERATION - Enum constant in enum class org.apache.wayang.giraph.Algorithm.PageRankParameters.PageRankEnum
- ITERATION_CONVERGENCE_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.LoopOperator
- ITERATION_CONVERGENCE_OUTPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.LoopOperator
- ITERATION_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.DoWhileOperator
- ITERATION_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.LoopOperator
- ITERATION_INPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.RepeatOperator
- ITERATION_OUTPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.DoWhileOperator
- ITERATION_OUTPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.LoopOperator
- ITERATION_OUTPUT_INDEX - Static variable in class org.apache.wayang.basic.operators.RepeatOperator
- IterationImplementation(int, PlanImplementation) - Constructor for class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- IterationImplementation(LoopImplementation.IterationImplementation) - Constructor for class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- iterator() - Method in class org.apache.wayang.core.api.configuration.CollectionProvider
- iterator() - Method in class org.apache.wayang.core.util.Bitmask
- iterator() - Method in class org.apache.wayang.core.util.Canonicalizer
- iterator() - Method in class org.apache.wayang.core.util.Counter
- iterator() - Method in class org.apache.wayang.core.util.CrossProductIterable
- iterator() - Method in class org.apache.wayang.core.util.json.WayangJsonArray
- Iterators - Class in org.apache.wayang.core.util
-
Utilities for the work with
Iterator
s. - Iterators() - Constructor for class org.apache.wayang.core.util.Iterators
J
- Java - Class in org.apache.wayang.java
-
Register for relevant components of this module.
- Java() - Constructor for class org.apache.wayang.java.Java
- JAVA - Enum constant in enum class org.apache.wayang.ml4all.abstraction.plan.Platforms
- JavaAmazonS3Source - Class in org.apache.wayang.java.operators
-
This is execution operator that implements the
AmazonS3Source
. - JavaAmazonS3Source(String, String, String) - Constructor for class org.apache.wayang.java.operators.JavaAmazonS3Source
- JavaAmazonS3Source(AmazonS3Source) - Constructor for class org.apache.wayang.java.operators.JavaAmazonS3Source
-
Copies an instance (exclusive of broadcasts).
- JavaAzureBlobStorageSource - Class in org.apache.wayang.java.operators
-
This is execution operator that implements the
AzureBlobStorageSource
. - JavaAzureBlobStorageSource(String, String, String) - Constructor for class org.apache.wayang.java.operators.JavaAzureBlobStorageSource
- JavaAzureBlobStorageSource(AzureBlobStorageSource) - Constructor for class org.apache.wayang.java.operators.JavaAzureBlobStorageSource
-
Copies an instance (exclusive of broadcasts).
- JavaBasicPlugin - Class in org.apache.wayang.java.plugin
- JavaBasicPlugin() - Constructor for class org.apache.wayang.java.plugin.JavaBasicPlugin
- JavaCartesianOperator<InputType0,
InputType1> - Class in org.apache.wayang.java.operators -
Java implementation of the
CartesianOperator
. - JavaCartesianOperator(CartesianOperator<InputType0, InputType1>) - Constructor for class org.apache.wayang.java.operators.JavaCartesianOperator
-
Copies an instance (exclusive of broadcasts).
- JavaCartesianOperator(DataSetType<InputType0>, DataSetType<InputType1>) - Constructor for class org.apache.wayang.java.operators.JavaCartesianOperator
-
Creates a new instance.
- JavaChannelConversionPlugin - Class in org.apache.wayang.java.plugin
- JavaChannelConversionPlugin() - Constructor for class org.apache.wayang.java.plugin.JavaChannelConversionPlugin
- JavaChannelInstance - Interface in org.apache.wayang.java.channels
-
Defines execution logic to handle a
Channel
. - JavaCoGroupOperator<InputType0,
InputType1, KeyType> - Class in org.apache.wayang.java.operators -
Java implementation of the
CoGroupOperator
. - JavaCoGroupOperator(CoGroupOperator<InputType0, InputType1, KeyType>) - Constructor for class org.apache.wayang.java.operators.JavaCoGroupOperator
-
Copies an instance (exclusive of broadcasts).
- JavaCoGroupOperator(DataSetType<InputType0>, DataSetType<InputType1>, TransformationDescriptor<InputType0, KeyType>, TransformationDescriptor<InputType1, KeyType>) - Constructor for class org.apache.wayang.java.operators.JavaCoGroupOperator
-
Creates a new instance.
- JavaCollectionSource<T> - Class in org.apache.wayang.java.operators
-
This is execution operator implements the
TextFileSource
. - JavaCollectionSource(Collection<T>, DataSetType<T>) - Constructor for class org.apache.wayang.java.operators.JavaCollectionSource
- JavaCollectionSource(CollectionSource<T>) - Constructor for class org.apache.wayang.java.operators.JavaCollectionSource
-
Copies an instance (exclusive of broadcasts).
- JavaCollectionSourceProfiler - Class in org.apache.wayang.profiler.java
- JavaCollectionSourceProfiler(Supplier<?>) - Constructor for class org.apache.wayang.profiler.java.JavaCollectionSourceProfiler
- JavaCollectOperator<Type> - Class in org.apache.wayang.java.operators
-
Converts
StreamChannel
into aCollectionChannel
- JavaCollectOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.java.operators.JavaCollectOperator
- JavaCountOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
CountOperator
. - JavaCountOperator(CountOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaCountOperator
-
Copies an instance (exclusive of broadcasts).
- JavaCountOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.java.operators.JavaCountOperator
-
Creates a new instance.
- JavaCSVTableSource<T> - Class in org.apache.wayang.api.sql.sources.fs
- JavaCSVTableSource(String, DataSetType<T>, List<RelDataType>) - Constructor for class org.apache.wayang.api.sql.sources.fs.JavaCSVTableSource
-
Table source with default seperator ';'
- JavaCSVTableSource(String, DataSetType<T>, List<RelDataType>, char) - Constructor for class org.apache.wayang.api.sql.sources.fs.JavaCSVTableSource
-
Constructor with custom separator
- JavaDistinctOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
DistinctOperator
. - JavaDistinctOperator(DistinctOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaDistinctOperator
-
Copies an instance (exclusive of broadcasts).
- JavaDistinctOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.java.operators.JavaDistinctOperator
-
Creates a new instance.
- JavaDoWhileOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.java.operators -
Java implementation of the
DoWhileOperator
. - JavaDoWhileOperator(DoWhileOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.java.operators.JavaDoWhileOperator
-
Creates a new instance.
- JavaDoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.java.operators.JavaDoWhileOperator
-
Creates a new instance.
- JavaDoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.java.operators.JavaDoWhileOperator
- JavaExecutionContext - Class in org.apache.wayang.java.execution
-
ExecutionContext
implementation for theJavaPlatform
. - JavaExecutionContext(JavaExecutionOperator, ChannelInstance[], int) - Constructor for class org.apache.wayang.java.execution.JavaExecutionContext
- JavaExecutionOperator - Interface in org.apache.wayang.java.operators
-
Execution operator for the Java platform.
- JavaExecutor - Class in org.apache.wayang.java.execution
-
Executor
implementation for theJavaPlatform
. - JavaExecutor(JavaPlatform, Job) - Constructor for class org.apache.wayang.java.execution.JavaExecutor
- JavaFilterOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
FilterOperator
. - JavaFilterOperator(FilterOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaFilterOperator
-
Copies an instance (exclusive of broadcasts).
- JavaFilterOperator(DataSetType<Type>, FunctionDescriptor.SerializablePredicate<Type>) - Constructor for class org.apache.wayang.java.operators.JavaFilterOperator
- JavaFilterOperator(DataSetType<Type>, PredicateDescriptor<Type>) - Constructor for class org.apache.wayang.java.operators.JavaFilterOperator
-
Creates a new instance.
- JavaFlatMapOperator<InputType,
OutputType> - Class in org.apache.wayang.java.operators -
Java implementation of the
FlatMapOperator
. - JavaFlatMapOperator(FlatMapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.java.operators.JavaFlatMapOperator
-
Copies an instance (exclusive of broadcasts).
- JavaFlatMapOperator(DataSetType<InputType>, DataSetType<OutputType>, FlatMapDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.java.operators.JavaFlatMapOperator
-
Creates a new instance.
- JavaGlobalMaterializedGroupOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
GlobalMaterializedGroupOperator
. - JavaGlobalMaterializedGroupOperator(Class<Type>) - Constructor for class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
- JavaGlobalMaterializedGroupOperator(GlobalMaterializedGroupOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
-
Copies an instance (exclusive of broadcasts).
- JavaGlobalMaterializedGroupOperator(DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.java.operators.JavaGlobalMaterializedGroupOperator
- JavaGlobalReduceOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
GlobalReduceOperator
. - JavaGlobalReduceOperator(GlobalReduceOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaGlobalReduceOperator
-
Copies an instance (exclusive of broadcasts).
- JavaGlobalReduceOperator(DataSetType<Type>, ReduceDescriptor<Type>) - Constructor for class org.apache.wayang.java.operators.JavaGlobalReduceOperator
-
Creates a new instance.
- JavaGoogleCloudStorageSource - Class in org.apache.wayang.java.operators
- JavaGoogleCloudStorageSource(String, String, String) - Constructor for class org.apache.wayang.java.operators.JavaGoogleCloudStorageSource
- JavaGoogleCloudStorageSource(GoogleCloudStorageSource) - Constructor for class org.apache.wayang.java.operators.JavaGoogleCloudStorageSource
- JavaGraphPlugin - Class in org.apache.wayang.java.plugin
- JavaGraphPlugin() - Constructor for class org.apache.wayang.java.plugin.JavaGraphPlugin
- JavaIEJoinOperator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input> - Class in org.apache.wayang.iejoin.operators -
Java implementation of the
IEJoinOperator
. - JavaIEJoinOperator(DataSetType<Input>, DataSetType<Input>, TransformationDescriptor<Input, Type0>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.JavaIEJoinOperator
-
Creates a new instance.
- JavaIESelfJoinOperator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input> - Class in org.apache.wayang.iejoin.operators -
Java implementation of the
IESelfJoinOperator
. - JavaIESelfJoinOperator(DataSetType<Input>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.JavaIESelfJoinOperator
-
Creates a new instance.
- JavaIntersectOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
IntersectOperator
. - JavaIntersectOperator(Class<Type>) - Constructor for class org.apache.wayang.java.operators.JavaIntersectOperator
- JavaIntersectOperator(IntersectOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaIntersectOperator
-
Copies an instance (exclusive of broadcasts).
- JavaIntersectOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.java.operators.JavaIntersectOperator
- JavaJoinOperator<InputType0,
InputType1, KeyType> - Class in org.apache.wayang.java.operators -
Java implementation of the
JoinOperator
. - JavaJoinOperator(JoinOperator<InputType0, InputType1, KeyType>) - Constructor for class org.apache.wayang.java.operators.JavaJoinOperator
-
Copies an instance (exclusive of broadcasts).
- JavaJoinOperator(DataSetType<InputType0>, DataSetType<InputType1>, TransformationDescriptor<InputType0, KeyType>, TransformationDescriptor<InputType1, KeyType>) - Constructor for class org.apache.wayang.java.operators.JavaJoinOperator
-
Creates a new instance.
- JavaKafkaTopicSink<T> - Class in org.apache.wayang.java.operators
-
Implementation fo the
KafkaTopicSink
for theJavaPlatform
. - JavaKafkaTopicSink(String, TransformationDescriptor<T, String>) - Constructor for class org.apache.wayang.java.operators.JavaKafkaTopicSink
- JavaKafkaTopicSink(KafkaTopicSink<T>) - Constructor for class org.apache.wayang.java.operators.JavaKafkaTopicSink
- JavaKafkaTopicSource - Class in org.apache.wayang.java.operators
- JavaKafkaTopicSource(String) - Constructor for class org.apache.wayang.java.operators.JavaKafkaTopicSource
- JavaKafkaTopicSource(String, String) - Constructor for class org.apache.wayang.java.operators.JavaKafkaTopicSource
- JavaKafkaTopicSource(KafkaTopicSource) - Constructor for class org.apache.wayang.java.operators.JavaKafkaTopicSource
- JavaLocalCallbackSink<T extends Serializable> - Class in org.apache.wayang.java.operators
-
Implementation of the
LocalCallbackSink
operator for the Java platform. - JavaLocalCallbackSink(Consumer<T>, DataSetType) - Constructor for class org.apache.wayang.java.operators.JavaLocalCallbackSink
-
Creates a new instance.
- JavaLocalCallbackSink(LocalCallbackSink<T>) - Constructor for class org.apache.wayang.java.operators.JavaLocalCallbackSink
-
Copies an instance (exclusive of broadcasts).
- JavaLoopOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.java.operators -
Java implementation of the
LoopOperator
. - JavaLoopOperator(LoopOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.java.operators.JavaLoopOperator
-
Creates a copy of the given
LoopOperator
. - JavaLoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.java.operators.JavaLoopOperator
-
Creates a new instance.
- JavaLoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.java.operators.JavaLoopOperator
- JavaMapOperator<InputType,
OutputType> - Class in org.apache.wayang.java.operators -
Java implementation of the
MapOperator
. - JavaMapOperator(MapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.java.operators.JavaMapOperator
-
Copies an instance (exclusive of broadcasts).
- JavaMapOperator(DataSetType<InputType>, DataSetType<OutputType>, TransformationDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.java.operators.JavaMapOperator
-
Creates a new instance.
- JavaMapPartitionsOperator<InputType,
OutputType> - Class in org.apache.wayang.java.operators -
Java implementation of the
MapPartitionsOperator
. - JavaMapPartitionsOperator(MapPartitionsOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.java.operators.JavaMapPartitionsOperator
-
Copies an instance (exclusive of broadcasts).
- JavaMapPartitionsOperator(DataSetType<InputType>, DataSetType<OutputType>, MapPartitionsDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.java.operators.JavaMapPartitionsOperator
-
Creates a new instance.
- javaMappings - Static variable in class org.apache.wayang.iejoin.mapping.Mappings
-
Mapping
s towards theJavaPlatform
. - JavaMaterializedGroupByOperator<Type,
KeyType> - Class in org.apache.wayang.java.operators -
Java implementation of the
MaterializedGroupByOperator
. - JavaMaterializedGroupByOperator(MaterializedGroupByOperator<Type, KeyType>) - Constructor for class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
-
Copies an instance (exclusive of broadcasts).
- JavaMaterializedGroupByOperator(TransformationDescriptor<Type, KeyType>, DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.java.operators.JavaMaterializedGroupByOperator
- JavaObjectFileSink<T> - Class in org.apache.wayang.java.operators
-
Operator
for theJavaPlatform
that creates a sequence file. - JavaObjectFileSink(String, DataSetType<T>) - Constructor for class org.apache.wayang.java.operators.JavaObjectFileSink
- JavaObjectFileSink(ObjectFileSink<T>) - Constructor for class org.apache.wayang.java.operators.JavaObjectFileSink
- JavaObjectFileSink(DataSetType<T>) - Constructor for class org.apache.wayang.java.operators.JavaObjectFileSink
- JavaObjectFileSink.StreamChunker - Class in org.apache.wayang.java.operators
-
Utility to chunk a
Stream
into portions of fixed size. - JavaObjectFileSource<T> - Class in org.apache.wayang.java.operators
-
Operator
for theJavaPlatform
that creates a sequence file. - JavaObjectFileSource(String, DataSetType<T>) - Constructor for class org.apache.wayang.java.operators.JavaObjectFileSource
- JavaObjectFileSource(ObjectFileSource<T>) - Constructor for class org.apache.wayang.java.operators.JavaObjectFileSource
- JavaObjectFileSource(DataSetType<T>) - Constructor for class org.apache.wayang.java.operators.JavaObjectFileSource
- JavaPageRankOperator - Class in org.apache.wayang.java.operators.graph
-
Java implementation of the
PageRankOperator
. - JavaPageRankOperator(int) - Constructor for class org.apache.wayang.java.operators.graph.JavaPageRankOperator
- JavaPageRankOperator(PageRankOperator) - Constructor for class org.apache.wayang.java.operators.graph.JavaPageRankOperator
- JavaParquetSource - Class in org.apache.wayang.java.operators
-
This is execution operator implements the
ParquetSource
. - JavaParquetSource(String, String[]) - Constructor for class org.apache.wayang.java.operators.JavaParquetSource
- JavaParquetSource(ParquetSource) - Constructor for class org.apache.wayang.java.operators.JavaParquetSource
-
Copies an instance (exclusive of broadcasts).
- JavaPlatform - Class in org.apache.wayang.java.platform
- javaPlugin() - Static method in class org.apache.wayang.iejoin.IEJoin
- JavaRandomSampleOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
JavaRandomSampleOperator
. - JavaRandomSampleOperator(SampleOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaRandomSampleOperator
-
Copies an instance (exclusive of broadcasts).
- JavaRandomSampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, FunctionDescriptor.SerializableLongUnaryOperator) - Constructor for class org.apache.wayang.java.operators.JavaRandomSampleOperator
-
Creates a new instance.
- JavaReduceByOperator<Type,
KeyType> - Class in org.apache.wayang.java.operators -
Java implementation of the
ReduceByOperator
. - JavaReduceByOperator(ReduceByOperator<Type, KeyType>) - Constructor for class org.apache.wayang.java.operators.JavaReduceByOperator
-
Copies an instance (exclusive of broadcasts).
- JavaReduceByOperator(DataSetType<Type>, TransformationDescriptor<Type, KeyType>, ReduceDescriptor<Type>) - Constructor for class org.apache.wayang.java.operators.JavaReduceByOperator
-
Creates a new instance.
- JavaRepeatOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
DoWhileOperator
. - JavaRepeatOperator(int, DataSetType<Type>) - Constructor for class org.apache.wayang.java.operators.JavaRepeatOperator
-
Creates a new instance.
- JavaRepeatOperator(RepeatOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaRepeatOperator
- JavaReservoirSampleOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
JavaReservoirSampleOperator
. - JavaReservoirSampleOperator(SampleOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaReservoirSampleOperator
-
Copies an instance (exclusive of broadcasts).
- JavaReservoirSampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, FunctionDescriptor.SerializableLongUnaryOperator) - Constructor for class org.apache.wayang.java.operators.JavaReservoirSampleOperator
-
Creates a new instance.
- JavaSortOperator<Type,
Key> - Class in org.apache.wayang.java.operators -
Java implementation of the
SortOperator
. - JavaSortOperator(SortOperator<Type, Key>) - Constructor for class org.apache.wayang.java.operators.JavaSortOperator
-
Copies an instance (exclusive of broadcasts).
- JavaSortOperator(TransformationDescriptor<Type, Key>, DataSetType<Type>) - Constructor for class org.apache.wayang.java.operators.JavaSortOperator
-
Creates a new instance.
- JavaTextFileSink<T> - Class in org.apache.wayang.java.operators
-
Implementation fo the
TextFileSink
for theJavaPlatform
. - JavaTextFileSink(String, TransformationDescriptor<T, String>) - Constructor for class org.apache.wayang.java.operators.JavaTextFileSink
- JavaTextFileSink(TextFileSink<T>) - Constructor for class org.apache.wayang.java.operators.JavaTextFileSink
- JavaTextFileSource - Class in org.apache.wayang.java.operators
-
This is execution operator implements the
TextFileSource
. - JavaTextFileSource(String) - Constructor for class org.apache.wayang.java.operators.JavaTextFileSource
- JavaTextFileSource(TextFileSource) - Constructor for class org.apache.wayang.java.operators.JavaTextFileSource
-
Copies an instance (exclusive of broadcasts).
- JavaTextFileSourceProfiler - Class in org.apache.wayang.profiler.java
-
OperatorProfiler
for sources. - JavaTextFileSourceProfiler(Supplier<String>, String) - Constructor for class org.apache.wayang.profiler.java.JavaTextFileSourceProfiler
- JavaTsvFileSink<T extends Tuple2<?,
?>> - Class in org.apache.wayang.java.operators -
Operator
for theJavaPlatform
that creates a TSV file. - JavaTsvFileSink(String, DataSetType<T>) - Constructor for class org.apache.wayang.java.operators.JavaTsvFileSink
- JavaTsvFileSink(DataSetType<T>) - Constructor for class org.apache.wayang.java.operators.JavaTsvFileSink
- JavaTsvFileSource<T> - Class in org.apache.wayang.java.operators
-
Operator
for theJavaPlatform
that creates a sequence file. - JavaTsvFileSource(String, DataSetType) - Constructor for class org.apache.wayang.java.operators.JavaTsvFileSource
- JavaTsvFileSource(DataSetType<Tuple2>) - Constructor for class org.apache.wayang.java.operators.JavaTsvFileSource
- JavaUnionAllOperator<Type> - Class in org.apache.wayang.java.operators
-
Java implementation of the
UnionAllOperator
. - JavaUnionAllOperator(UnionAllOperator<Type>) - Constructor for class org.apache.wayang.java.operators.JavaUnionAllOperator
-
Copies an instance (exclusive of broadcasts).
- JavaUnionAllOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.java.operators.JavaUnionAllOperator
-
Creates a new instance.
- jdbcCatalogName - Variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- JdbcExecutionOperator - Interface in org.apache.wayang.jdbc.operators
- JdbcExecutor - Class in org.apache.wayang.jdbc.execution
-
Executor
implementation for theJdbcPlatformTemplate
. - JdbcExecutor(JdbcPlatformTemplate, Job) - Constructor for class org.apache.wayang.jdbc.execution.JdbcExecutor
- JdbcFilterOperator - Class in org.apache.wayang.jdbc.operators
-
Template for JDBC-based
FilterOperator
. - JdbcFilterOperator(FilterOperator<Record>) - Constructor for class org.apache.wayang.jdbc.operators.JdbcFilterOperator
- JdbcFilterOperator(PredicateDescriptor<Record>) - Constructor for class org.apache.wayang.jdbc.operators.JdbcFilterOperator
- JdbcJoinOperator<KeyType> - Class in org.apache.wayang.jdbc.operators
-
PostgreSQL implementation for the
JoinOperator
. - JdbcJoinOperator(JoinOperator<Record, Record, KeyType>) - Constructor for class org.apache.wayang.jdbc.operators.JdbcJoinOperator
-
Copies an instance
- JdbcJoinOperator(TransformationDescriptor<Record, KeyType>, TransformationDescriptor<Record, KeyType>) - Constructor for class org.apache.wayang.jdbc.operators.JdbcJoinOperator
-
Creates a new instance.
- jdbcName - Variable in class org.apache.wayang.genericjdbc.operators.GenericJdbcTableSource
-
Creates a new instance.
- jdbcPasswordProperty - Variable in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- JdbcPlatformTemplate - Class in org.apache.wayang.jdbc.platform
-
Platform
implementation for a JDBC-accessible database. - JdbcPlatformTemplate(String, String) - Constructor for class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- JdbcProjectionOperator - Class in org.apache.wayang.jdbc.operators
-
Projects the fields of
Record
s. - JdbcProjectionOperator(String...) - Constructor for class org.apache.wayang.jdbc.operators.JdbcProjectionOperator
- JdbcProjectionOperator(ProjectionDescriptor<Record, Record>) - Constructor for class org.apache.wayang.jdbc.operators.JdbcProjectionOperator
- JdbcProjectionOperator(MapOperator<Record, Record>) - Constructor for class org.apache.wayang.jdbc.operators.JdbcProjectionOperator
-
Copies an instance (exclusive of broadcasts).
- jdbcSchema - Variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- JdbcSchema - Class in org.apache.wayang.api.sql.calcite.jdbc
-
Implementation of
Schema
that is backed by a JDBC data source. - JdbcSchema(DataSource, SqlDialect, JdbcConvention, String, String) - Constructor for class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
-
Creates a JDBC schema.
- JdbcSchema.Factory - Class in org.apache.wayang.api.sql.calcite.jdbc
-
Schema factory that creates a
JdbcSchema
. - JdbcSchema.Foo - Interface in org.apache.wayang.api.sql.calcite.jdbc
-
Do not use.
- jdbcSchemaName - Variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- JDBCStorage - Class in org.apache.wayang.commons.util.profiledb.storage
- JDBCStorage(URI) - Constructor for class org.apache.wayang.commons.util.profiledb.storage.JDBCStorage
- JdbcTable - Class in org.apache.wayang.api.sql.calcite.jdbc
-
Queryable that gets its data from a table within a JDBC connection.
- jdbcTableName - Variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- JdbcTableSource - Class in org.apache.wayang.jdbc.operators
-
PostgreSQL implementation for the
TableSource
. - JdbcTableSource(String, String...) - Constructor for class org.apache.wayang.jdbc.operators.JdbcTableSource
-
Creates a new instance.
- JdbcTableSource(JdbcTableSource) - Constructor for class org.apache.wayang.jdbc.operators.JdbcTableSource
-
Copies an instance (exclusive of broadcasts).
- jdbcTableType - Variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- jdbcUrlProperty - Variable in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- jdbcUserProperty - Variable in class org.apache.wayang.jdbc.platform.JdbcPlatformTemplate
- job - Variable in class org.apache.wayang.core.optimizer.OptimizationContext
-
The
Job
whoseWayangPlan
is to be optimized. - job - Variable in class org.apache.wayang.core.platform.PushExecutorTemplate
- Job - Class in org.apache.wayang.core.api
-
Describes a job that is to be executed using Wayang.
- Job - Interface in org.apache.wayang.spark.monitoring.interfaces
-
The Job interface represents a job to be executed in a distributed system.
- JobEnd - Class in org.apache.wayang.spark.monitoring.metrics
-
JobEnd class represents a job's end in a system.
- JobEnd() - Constructor for class org.apache.wayang.spark.monitoring.metrics.JobEnd
- JobStart - Class in org.apache.wayang.spark.monitoring.metrics
-
JobStart class represents a job's start in a system.
- JobStart() - Constructor for class org.apache.wayang.spark.monitoring.metrics.JobStart
- JoinFlattenResult - Class in org.apache.wayang.api.sql.calcite.converter.functions
- JoinFlattenResult() - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.JoinFlattenResult
- JoinKeyExtractor - Class in org.apache.wayang.api.sql.calcite.converter.functions
- JoinKeyExtractor(int) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.JoinKeyExtractor
- JoinMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
JoinOperator
toFlinkJoinOperator
. - JoinMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
JoinOperator
toJavaJoinOperator
. - JoinMapping - Class in org.apache.wayang.postgres.mapping
-
Mapping from
JoinOperator
toPostgresJoinOperator
. - JoinMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
JoinOperator
toSparkJoinOperator
. - JoinMapping() - Constructor for class org.apache.wayang.flink.mapping.JoinMapping
- JoinMapping() - Constructor for class org.apache.wayang.java.mapping.JoinMapping
- JoinMapping() - Constructor for class org.apache.wayang.postgres.mapping.JoinMapping
- JoinMapping() - Constructor for class org.apache.wayang.spark.mapping.JoinMapping
- JoinOperator<InputType0,
InputType1, Key> - Class in org.apache.wayang.basic.operators -
This operator returns the cartesian product of elements of input datasets.
- JoinOperator(JoinOperator<InputType0, InputType1, Key>) - Constructor for class org.apache.wayang.basic.operators.JoinOperator
-
Copies an instance (exclusive of broadcasts).
- JoinOperator(FunctionDescriptor.SerializableFunction<InputType0, Key>, FunctionDescriptor.SerializableFunction<InputType1, Key>, Class<InputType0>, Class<InputType1>, Class<Key>) - Constructor for class org.apache.wayang.basic.operators.JoinOperator
- JoinOperator(TransformationDescriptor<InputType0, Key>, TransformationDescriptor<InputType1, Key>) - Constructor for class org.apache.wayang.basic.operators.JoinOperator
- JoinOperator(TransformationDescriptor<InputType0, Key>, TransformationDescriptor<InputType1, Key>, DataSetType<InputType0>, DataSetType<InputType1>) - Constructor for class org.apache.wayang.basic.operators.JoinOperator
- JoinVertexWithEdgesMatch() - Constructor for class org.apache.wayang.flink.operators.FlinkPageRankOperator.JoinVertexWithEdgesMatch
- JsonSerializable - Interface in org.apache.wayang.core.util
-
This interface prescribes implementing instances to be able to provide itself as a
WayangJsonObj
. - JsonSerializable.Serializer<T extends JsonSerializable> - Class in org.apache.wayang.core.util
-
A
JsonSerializer
implementation to serializeJsonSerializable
s. - JsonSerializables - Class in org.apache.wayang.core.util
-
Utility to deal with
JsonSerializable
s. - JsonSerializables() - Constructor for class org.apache.wayang.core.util.JsonSerializables
- jsonSerializer - Static variable in class org.apache.wayang.core.optimizer.costs.SimpleEstimationContext
- jsonSerializer - Static variable in class org.apache.wayang.core.platform.Platform
-
Default
JsonSerializer
implementation that stores theClass
of the instance and then tries to deserialize by invoking the staticgetInstance()
method. - JsonSerializer<T> - Interface in org.apache.wayang.core.util
-
Alternative to
JsonSerializable
: Externalizes serialization logic. - JuelFunction(String, Class<T>, Map<String, Class<?>>) - Constructor for class org.apache.wayang.core.util.JuelUtils.JuelFunction
- JuelUtils - Class in org.apache.wayang.core.util
-
Utilities to deal with JUEL expressions.
- JuelUtils() - Constructor for class org.apache.wayang.core.util.JuelUtils
- JuelUtils.JuelFunction<T> - Class in org.apache.wayang.core.util
- Junction - Class in org.apache.wayang.core.platform
-
Describes the implementation of one
OutputSlot
to its occupiedInputSlot
s. - Junction(OutputSlot<?>, List<InputSlot<?>>, List<OptimizationContext>) - Constructor for class org.apache.wayang.core.platform.Junction
K
- k - Variable in class org.apache.wayang.basic.operators.KMeansOperator
- KafkaTopicSink<T> - Class in org.apache.wayang.basic.operators
-
This
UnarySink
writes all incoming data quanta to a single Kafka topic. - KafkaTopicSink() - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSink
- KafkaTopicSink(String, Class<T>) - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSink
-
Creates a new instance with default formatting.
- KafkaTopicSink(String, FunctionDescriptor.SerializableFunction<T, String>, Class<T>) - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSink
-
Creates a new instance.
- KafkaTopicSink(String, TransformationDescriptor<T, String>) - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSink
-
Creates a new instance.
- KafkaTopicSink(KafkaTopicSink<T>) - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSink
-
Creates a copied instance.
- KafkaTopicSinkMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
KafkaTopicSink
toJavaKafkaTopicSink
. - KafkaTopicSinkMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
KafkaTopicSink
toSparkKafkaTopicSink
. - KafkaTopicSinkMapping() - Constructor for class org.apache.wayang.java.mapping.KafkaTopicSinkMapping
- KafkaTopicSinkMapping() - Constructor for class org.apache.wayang.spark.mapping.KafkaTopicSinkMapping
- KafkaTopicSource - Class in org.apache.wayang.basic.operators
-
This source reads messages from a Kafka topic and outputs the messages as data units.
- KafkaTopicSource(String) - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSource
- KafkaTopicSource(String, String) - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSource
- KafkaTopicSource(KafkaTopicSource) - Constructor for class org.apache.wayang.basic.operators.KafkaTopicSource
-
Copies an instance (exclusive of broadcasts).
- KafkaTopicSource.CardinalityEstimator - Class in org.apache.wayang.basic.operators
- KafkaTopicSourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
KafkaTopicSource
toJavaKafkaTopicSource
. - KafkaTopicSourceMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
KafkaTopicSource
toSparkKafkaTopicSource
. - KafkaTopicSourceMapping() - Constructor for class org.apache.wayang.java.mapping.KafkaTopicSourceMapping
- KafkaTopicSourceMapping() - Constructor for class org.apache.wayang.spark.mapping.KafkaTopicSourceMapping
- kernelSize - Variable in class org.apache.wayang.basic.model.op.nn.Conv
- key - Variable in class org.apache.wayang.flink.compiler.KeySelectorFunction
- keyDescriptor - Variable in class org.apache.wayang.basic.operators.GroupByOperator
- keyDescriptor - Variable in class org.apache.wayang.basic.operators.MaterializedGroupByOperator
- keyDescriptor - Variable in class org.apache.wayang.basic.operators.ReduceByOperator
- keyDescriptor - Variable in class org.apache.wayang.basic.operators.SortOperator
- keyDescriptor0 - Variable in class org.apache.wayang.basic.operators.CoGroupOperator
- keyDescriptor0 - Variable in class org.apache.wayang.basic.operators.JoinOperator
- keyDescriptor1 - Variable in class org.apache.wayang.basic.operators.CoGroupOperator
- keyDescriptor1 - Variable in class org.apache.wayang.basic.operators.JoinOperator
- KeyExtractor(Function<T, K>) - Constructor for class org.apache.wayang.spark.compiler.FunctionCompiler.KeyExtractor
- KeyOrLoadSerializer(Configuration, EstimationContext) - Constructor for class org.apache.wayang.core.platform.AtomicExecution.KeyOrLoadSerializer
-
Creates a new instance.
- KeySelectorDistinct<T> - Class in org.apache.wayang.flink.compiler
-
Wrapper for
- KeySelectorDistinct() - Constructor for class org.apache.wayang.flink.compiler.KeySelectorDistinct
- KeySelectorFunction<T,
K> - Class in org.apache.wayang.flink.compiler -
Wrapper for
KeySelector
- KeySelectorFunction(TransformationDescriptor<T, K>) - Constructor for class org.apache.wayang.flink.compiler.KeySelectorFunction
- keySet() - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- KeyValueProvider<Key,
Value> - Class in org.apache.wayang.core.api.configuration -
Used by
Configuration
s to provide some value. - KeyValueProvider(KeyValueProvider<Key, Value>) - Constructor for class org.apache.wayang.core.api.configuration.KeyValueProvider
- KeyValueProvider(KeyValueProvider<Key, Value>, Configuration) - Constructor for class org.apache.wayang.core.api.configuration.KeyValueProvider
- KeyValueProvider.NoSuchKeyException - Exception in org.apache.wayang.core.api.configuration
- KILLED - Enum constant in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
- kMeans() - Static method in class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- kMeans() - Static method in class org.apache.wayang.basic.operators.PredictOperators
- KMeansCompute - Class in org.apache.wayang.ml4all.algorithms.kmeans
- KMeansCompute() - Constructor for class org.apache.wayang.ml4all.algorithms.kmeans.KMeansCompute
- KMeansConvergeOrMaxIterationsLoop - Class in org.apache.wayang.ml4all.algorithms.kmeans
- KMeansConvergeOrMaxIterationsLoop(double, int) - Constructor for class org.apache.wayang.ml4all.algorithms.kmeans.KMeansConvergeOrMaxIterationsLoop
- KMeansMapping - Class in org.apache.wayang.spark.mapping.ml
-
Mapping from
KMeansOperator
toSparkKMeansOperator
. - KMeansMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.KMeansMapping
- KMeansModel - Interface in org.apache.wayang.basic.model
- KMeansOperator - Class in org.apache.wayang.basic.operators
- KMeansOperator(int) - Constructor for class org.apache.wayang.basic.operators.KMeansOperator
- KMeansOperator(KMeansOperator) - Constructor for class org.apache.wayang.basic.operators.KMeansOperator
- KMeansStageWithZeros - Class in org.apache.wayang.ml4all.algorithms.kmeans
- KMeansStageWithZeros(int, int) - Constructor for class org.apache.wayang.ml4all.algorithms.kmeans.KMeansStageWithZeros
- KMeansUpdate - Class in org.apache.wayang.ml4all.algorithms.kmeans
- KMeansUpdate() - Constructor for class org.apache.wayang.ml4all.algorithms.kmeans.KMeansUpdate
L
- L_COMMENT - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
variable text, size 44
- L_COMMITDATE - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
fixed text, size 1
- L_DISCOUNT - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
decimal
- L_EXTENDEDPRICE - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
decimal
- L_LINENUMBER - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
integer
,PK
- L_LINESTATUS - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
fixed text, size 1
- L_LINESTATUS - Variable in class org.apache.wayang.apps.tpch.data.q1.GroupKey
- L_LINESTATUS - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- L_ORDERKEY - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
identifier
,PK
- L_PARTKEY - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
identifier
- L_QUANTITY - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
decimal
- L_RECEIPTDATE - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
fixed text, size 1
- L_RETURNFLAG - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
fixed text, size 1
- L_RETURNFLAG - Variable in class org.apache.wayang.apps.tpch.data.q1.GroupKey
- L_RETURNFLAG - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- L_SHIPDATE - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
fixed text, size 1
- L_SHIPINSTRUCT - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
fixed text, size 25
- L_SHIPMODE - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
fixed text, size 10
- L_SUPPKEY - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
identifier
- L_TAX - Variable in class org.apache.wayang.apps.tpch.data.LineItemTuple
-
decimal
- LABEL - Enum constant in enum class org.apache.wayang.basic.model.op.Input.Type
- LABEL - Static variable in class org.apache.wayang.spark.operators.ml.Attr
- LatentOperatorPruningStrategy - Class in org.apache.wayang.core.optimizer.enumeration
-
This
PlanEnumerationPruningStrategy
follows the idea that we can prune aPlanImplementation
, when there is a further one that is (i) better and (ii) has the exact same operators with still-to-be-connectedSlot
s. - LatentOperatorPruningStrategy() - Constructor for class org.apache.wayang.core.optimizer.enumeration.LatentOperatorPruningStrategy
- layer(Op) - Method in class org.apache.wayang.basic.model.DLModel.Builder
- LazyExecutionLineageNode - Class in org.apache.wayang.core.platform.lineage
-
A node wraps a
ChannelInstance
and keeps track of predecessor nodes. - LazyExecutionLineageNode() - Constructor for class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
- LazyExecutionLineageNode.Aggregator<T> - Interface in org.apache.wayang.core.platform.lineage
-
Callback interface for traversals of
LazyExecutionLineageNode
s, thereby accumulating the callback return values. - LazyExecutionLineageNode.CollectingAggregator - Class in org.apache.wayang.core.platform.lineage
-
LazyExecutionLineageNode.Aggregator
implementation that collects all visitedLazyExecutionLineageNode
contents. - learningRate - Variable in class org.apache.wayang.basic.model.optimizer.Optimizer
- length() - Method in class org.apache.wayang.core.util.json.WayangJsonArray
- length() - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- LessThan - Enum constant in enum class org.apache.wayang.iejoin.operators.IEJoinMasterOperator.JoinCondition
- LessThanEqual - Enum constant in enum class org.apache.wayang.iejoin.operators.IEJoinMasterOperator.JoinCondition
- letCompete(T, T, Random) - Method in class org.apache.wayang.profiler.log.sampling.ReservoirSampler
- LibSVMTransform - Class in org.apache.wayang.ml4all.algorithms.sgd
- LibSVMTransform(int) - Constructor for class org.apache.wayang.ml4all.algorithms.sgd.LibSVMTransform
- LimitedInputStream - Class in org.apache.wayang.core.util
-
InputStream
that is trimmed to a specified size. - LimitedInputStream(InputStream) - Constructor for class org.apache.wayang.core.util.LimitedInputStream
-
Create an unlimited instance.
- LimitedInputStream(InputStream, long) - Constructor for class org.apache.wayang.core.util.LimitedInputStream
-
Create a limited instance.
- Linear - Class in org.apache.wayang.basic.model.op.nn
- Linear(int, int, boolean) - Constructor for class org.apache.wayang.basic.model.op.nn.Linear
- Linear(int, int, boolean, String) - Constructor for class org.apache.wayang.basic.model.op.nn.Linear
- Linear(int, int, boolean, String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.Linear
- Linear(int, int, boolean, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.nn.Linear
- linearRegression() - Static method in class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- linearRegression() - Static method in class org.apache.wayang.basic.operators.PredictOperators
- LinearRegressionMapping - Class in org.apache.wayang.spark.mapping.ml
-
Mapping from
LinearRegressionOperator
toSparkLinearRegressionOperator
. - LinearRegressionMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.LinearRegressionMapping
- LinearRegressionModel - Interface in org.apache.wayang.basic.model
- LinearRegressionOperator - Class in org.apache.wayang.basic.operators
- LinearRegressionOperator(boolean) - Constructor for class org.apache.wayang.basic.operators.LinearRegressionOperator
- LinearRegressionOperator(LinearRegressionOperator) - Constructor for class org.apache.wayang.basic.operators.LinearRegressionOperator
- LinearSVCMapping - Class in org.apache.wayang.spark.mapping.ml
-
Mapping from
LinearSVCOperator
toSparkLinearSVCOperator
. - LinearSVCMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.LinearSVCMapping
- LinearSVCOperator - Class in org.apache.wayang.basic.operators
- LinearSVCOperator(int, double) - Constructor for class org.apache.wayang.basic.operators.LinearSVCOperator
- LinearSVCOperator(LinearSVCOperator) - Constructor for class org.apache.wayang.basic.operators.LinearSVCOperator
- LineItemTuple - Class in org.apache.wayang.apps.tpch.data
-
A tuple of the lineitem table.
- LineItemTuple() - Constructor for class org.apache.wayang.apps.tpch.data.LineItemTuple
- LineItemTuple(long, long, long, int, double, double, double, double, char, int, int, int, String, String, String) - Constructor for class org.apache.wayang.apps.tpch.data.LineItemTuple
- LineItemTuple.Parser - Class in org.apache.wayang.apps.tpch.data
-
Parses a
LineItemTuple
from a given CSV line (double quoted, comma-separated). - Link(int, int) - Constructor for class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.Link
- list1ASC - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- list1ASC - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- list1ASCSec - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- list1ASCSec - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- list2ASC - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- list2ASC - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- list2ASCSec - Variable in class org.apache.wayang.iejoin.operators.IEJoinOperator
- list2ASCSec - Variable in class org.apache.wayang.iejoin.operators.IESelfJoinOperator
- List2AttributesObjectSkinny<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>> - Class in org.apache.wayang.iejoin.operators.spark_helpers -
Created by khayyzy on 5/28/16.
- List2AttributesObjectSkinny(Data[], long) - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- listChildren(String) - Method in interface org.apache.wayang.core.util.fs.FileSystem
- listChildren(String) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- listChildren(String) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- listChildren(String) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- load() - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Bring
Experiment
s from current Storage to local variable - load() - Method in class org.apache.wayang.commons.util.profiledb.storage.FileStorage
-
Load
Experiment
s from aFile
. - load() - Method in class org.apache.wayang.commons.util.profiledb.storage.JDBCStorage
-
Load
Experiment
s from aFile
. - load() - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Bring
Experiment
s from current Storage to local variable - load(BufferedReader) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Load
Experiment
s from anReader
. - load(InputStream) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Bring
Experiment
s from current Storage to local variable - load(InputStream) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Load
Experiment
s from anInputStream
. - load(InputStream) - Method in class org.apache.wayang.core.api.Configuration
-
Adjusts this instance to the properties specified in the given file.
- load(String) - Method in class org.apache.wayang.core.api.Configuration
-
Adjusts this instance to the properties specified in the given file.
- load(String) - Static method in class org.apache.wayang.core.platform.Platform
-
Loads a specific
Platform
implementation. - loadConfig(String) - Static method in class org.apache.wayang.basic.operators.KafkaTopicSink
-
Load properties from a properties file or alternatively use the default properties with some sensitive values from environment variables.
- loadConfig(String) - Static method in class org.apache.wayang.basic.operators.KafkaTopicSource
-
Load properties from a properties file or alternatively use the default properties with some sensitive values from environment variables.
- LoadEstimate - Class in org.apache.wayang.core.optimizer.costs
-
An estimate of costs of some executable code expressed as a
ProbabilisticIntervalEstimate
. - LoadEstimate() - Constructor for class org.apache.wayang.core.optimizer.costs.LoadEstimate
- LoadEstimate(long) - Constructor for class org.apache.wayang.core.optimizer.costs.LoadEstimate
- LoadEstimate(long, long, double) - Constructor for class org.apache.wayang.core.optimizer.costs.LoadEstimate
- LoadEstimator - Class in org.apache.wayang.core.optimizer.costs
-
Describes the resource utilization of something executable within an
EstimationContext
, such as anExecutionOperator
or aFunctionDescriptor
. - LoadEstimator(CardinalityEstimate) - Constructor for class org.apache.wayang.core.optimizer.costs.LoadEstimator
-
Create a new instance.
- LoadEstimator.SinglePointEstimationFunction - Interface in org.apache.wayang.core.optimizer.costs
-
Functional interface for lambda expressions to express single-point load estimation functions.
- LoadProfile - Class in org.apache.wayang.core.optimizer.costs
-
Reflects the (estimated) required resources of an
Operator
orFunctionDescriptor
. - LoadProfile(LoadEstimate, LoadEstimate) - Constructor for class org.apache.wayang.core.optimizer.costs.LoadProfile
-
Creates a new instance without network and disk usage, full resource utilization, and no overhead.
- LoadProfile(LoadEstimate, LoadEstimate, LoadEstimate, LoadEstimate) - Constructor for class org.apache.wayang.core.optimizer.costs.LoadProfile
-
Creates a new instance with full resource utilization, and no overhead.
- LoadProfile(LoadEstimate, LoadEstimate, LoadEstimate, LoadEstimate, double, long) - Constructor for class org.apache.wayang.core.optimizer.costs.LoadProfile
-
Creates a new instance.
- LoadProfileEstimator - Interface in org.apache.wayang.core.optimizer.costs
-
Estimates the
LoadProfile
of some executable artifact that takes some input data quanta and produces them. - LoadProfileEstimators - Class in org.apache.wayang.core.optimizer.costs
-
Utilities to deal with
LoadProfileEstimator
s. - LoadProfileToTimeConverter - Class in org.apache.wayang.core.optimizer.costs
-
Calculates a
TimeEstimate
for a linkLoadProfile
. - LoadProfileToTimeConverter(LoadToTimeConverter, LoadToTimeConverter, LoadToTimeConverter) - Constructor for class org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter
- LoadProfileToTimeConverter.ResourceTimeEstimateAggregator - Interface in org.apache.wayang.core.optimizer.costs
- loadResource(String) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Provides a resource as an
InputStream
. - LoadToTimeConverter - Class in org.apache.wayang.core.optimizer.costs
-
Converts a
LoadEstimate
into a time estimate. - LoadToTimeConverter() - Constructor for class org.apache.wayang.core.optimizer.costs.LoadToTimeConverter
- loadYaml(String) - Static method in class org.apache.wayang.core.plugin.DynamicPlugin
-
Loads a YAML file of the following format:
- LocalCallbackSink<T> - Class in org.apache.wayang.basic.operators
-
This sink executes a callback on each received data unit into a Java
Collection
. - LocalCallbackSink(Class<T>) - Constructor for class org.apache.wayang.basic.operators.LocalCallbackSink
-
Convnience constructor, defaults to StdoutSink
- LocalCallbackSink(Consumer<T>, Class<T>) - Constructor for class org.apache.wayang.basic.operators.LocalCallbackSink
-
Creates a new instance.
- LocalCallbackSink(Consumer<T>, DataSetType<T>) - Constructor for class org.apache.wayang.basic.operators.LocalCallbackSink
-
Creates a new instance.
- LocalCallbackSink(LocalCallbackSink<T>) - Constructor for class org.apache.wayang.basic.operators.LocalCallbackSink
-
Copies an instance (exclusive of broadcasts).
- LocalCallbackSink(FunctionDescriptor.SerializableConsumer<T>, Class<T>) - Constructor for class org.apache.wayang.basic.operators.LocalCallbackSink
-
Creates a new instance.
- LocalCallbackSink(FunctionDescriptor.SerializableConsumer<T>, DataSetType<T>) - Constructor for class org.apache.wayang.basic.operators.LocalCallbackSink
-
Creates a new instance.
- LocalCallbackSinkMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
LocalCallbackSink
toFlinkLocalCallbackSink
. - LocalCallbackSinkMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
LocalCallbackSink
toJavaLocalCallbackSink
. - LocalCallbackSinkMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
LocalCallbackSink
toSparkLocalCallbackSink
. - LocalCallbackSinkMapping() - Constructor for class org.apache.wayang.flink.mapping.LocalCallbackSinkMapping
- LocalCallbackSinkMapping() - Constructor for class org.apache.wayang.java.mapping.LocalCallbackSinkMapping
- LocalCallbackSinkMapping() - Constructor for class org.apache.wayang.spark.mapping.LocalCallbackSinkMapping
- LocalFileSystem - Class in org.apache.wayang.core.util.fs
-
FileSystem
implementation for the local file system. - LocalFileSystem() - Constructor for class org.apache.wayang.core.util.fs.LocalFileSystem
- LocalStage - Class in org.apache.wayang.ml4all.abstraction.api
- LocalStage() - Constructor for class org.apache.wayang.ml4all.abstraction.api.LocalStage
- LogEvaluator - Class in org.apache.wayang.profiler.log
-
Evaluates a
Configuration
on aExecutionLog
. - LogEvaluator(Configuration) - Constructor for class org.apache.wayang.profiler.log.LogEvaluator
- logger - Variable in class org.apache.wayang.basic.operators.SampleOperator
- logger - Variable in class org.apache.wayang.core.api.configuration.KeyValueProvider
- logger - Variable in class org.apache.wayang.core.api.configuration.ValueProvider
- logger - Variable in class org.apache.wayang.core.mapping.PlanTransformation
- logger - Variable in class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
- logger - Variable in class org.apache.wayang.core.optimizer.OptimizationContext
- logger - Variable in class org.apache.wayang.core.plan.executionplan.Channel
- logger - Variable in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal
- logger - Variable in class org.apache.wayang.core.platform.CrossPlatformExecutor
- logger - Variable in class org.apache.wayang.core.platform.ExecutorTemplate
- logger - Variable in class org.apache.wayang.profiler.java.OperatorProfiler
- logger - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- logger - Variable in class org.apache.wayang.spark.monitoring.metrics.SparkListener
- logger() - Method in interface org.apache.wayang.core.util.Logging
-
Create a
Logger
for this instance. - Logging - Interface in org.apache.wayang.core.util
-
Provide logging via
Logger
. - LogicalOperator - Class in org.apache.wayang.ml4all.abstraction.api
-
An ML4all logical operator
- LogicalOperator() - Constructor for class org.apache.wayang.ml4all.abstraction.api.LogicalOperator
- LogicalOperatorWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - LogicalOperatorWrapper() - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapper
- LogicalOperatorWrapperWithModel<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers -
Logical Operator that uses the [[org.apache.wayang.ml4all.abstraction.plan.ML4allModel]] as input besides the data flowing from its input slot.
- LogicalOperatorWrapperWithModel() - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapperWithModel
- logisticGrowth(double, double, double, double) - Static method in class org.apache.wayang.core.optimizer.OptimizationUtils
-
Uses the right part of the logistic regression curve to model a strictly growing function between
g0
and 1. - logisticRegression() - Static method in class org.apache.wayang.basic.operators.PredictOperators
- LogisticRegressionMapping - Class in org.apache.wayang.spark.mapping.ml
-
Mapping from
LogisticRegressionOperator
toSparkLogisticRegressionOperator
. - LogisticRegressionMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.LogisticRegressionMapping
- LogisticRegressionModel - Interface in org.apache.wayang.basic.model
- LogisticRegressionOperator - Class in org.apache.wayang.basic.operators
- LogisticRegressionOperator(boolean) - Constructor for class org.apache.wayang.basic.operators.LogisticRegressionOperator
- LogisticRegressionOperator(LogisticRegressionOperator) - Constructor for class org.apache.wayang.basic.operators.LogisticRegressionOperator
- logTimeEstimates() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- Loop<R,
V> - Class in org.apache.wayang.ml4all.abstraction.api - Loop() - Constructor for class org.apache.wayang.ml4all.abstraction.api.Loop
- LoopCheckWrapper<V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers
- LoopCheckWrapper(Loop) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.LoopCheckWrapper
- LoopContext(OptimizationContext.OperatorContext) - Constructor for class org.apache.wayang.core.optimizer.OptimizationContext.LoopContext
- LoopConvergenceWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - LoopConvergenceWrapper(Loop) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.LoopConvergenceWrapper
- LoopEnumerator - Class in org.apache.wayang.core.optimizer.enumeration
-
Enumerator for
LoopSubplan
s. - LoopEnumerator(PlanEnumerator, OptimizationContext.LoopContext) - Constructor for class org.apache.wayang.core.optimizer.enumeration.LoopEnumerator
- LoopHeadAlternative - Class in org.apache.wayang.core.plan.wayangplan
-
Special
OperatorAlternative
forLoopHeadOperator
s. - LoopHeadAlternativeCardinalityPusher - Class in org.apache.wayang.core.optimizer.cardinality
-
CardinalityPusher
implementation forLoopHeadAlternative
s. - LoopHeadAlternativeCardinalityPusher(LoopHeadAlternative, Collection<InputSlot<?>>, Collection<OutputSlot<?>>, BiFunction<OperatorAlternative.Alternative, Configuration, CardinalityPusher>, Configuration) - Constructor for class org.apache.wayang.core.optimizer.cardinality.LoopHeadAlternativeCardinalityPusher
- LoopHeadOperator - Interface in org.apache.wayang.core.plan.wayangplan
-
Head of a
LoopSubplan
. - LoopHeadOperator.State - Enum Class in org.apache.wayang.core.plan.wayangplan
-
LoopHeadOperator
s can be stateful because they might be executed mulitple times. - LoopImplementation - Class in org.apache.wayang.core.optimizer.enumeration
-
Describes the enumeration of a
LoopSubplan
. - LoopImplementation(LoopImplementation) - Constructor for class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
-
Copy constructor.
- LoopImplementation(LoopSubplan) - Constructor for class org.apache.wayang.core.optimizer.enumeration.LoopImplementation
- LoopImplementation.IterationImplementation - Class in org.apache.wayang.core.optimizer.enumeration
-
Enumeration for a number of contiguous loop iterations.
- LoopIsolator - Class in org.apache.wayang.core.plan.wayangplan
-
Goes over a
WayangPlan
and isolates its loops. - LoopMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
LoopOperator
toFlinkLoopOperator
. - LoopMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
LoopOperator
toJavaLoopOperator
. - LoopMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
LoopOperator
toSparkLoopOperator
. - LoopMapping() - Constructor for class org.apache.wayang.flink.mapping.LoopMapping
- LoopMapping() - Constructor for class org.apache.wayang.java.mapping.LoopMapping
- LoopMapping() - Constructor for class org.apache.wayang.spark.mapping.LoopMapping
- LoopOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.basic.operators -
This operator has three inputs and three outputs.
- LoopOperator(Class<InputType>, Class<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.basic.operators.LoopOperator
- LoopOperator(LoopOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.basic.operators.LoopOperator
-
Creates a copy of the given
LoopOperator
. - LoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.basic.operators.LoopOperator
- LoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.basic.operators.LoopOperator
-
Creates a new instance.
- LoopSubplan - Class in org.apache.wayang.core.plan.wayangplan
-
Wraps a loop of
Operator
s. - LoopSubplanCardinalityPusher - Class in org.apache.wayang.core.optimizer.cardinality
-
CardinalityPusher
implementation forLoopSubplan
s. - LoopSubplanCardinalityPusher(LoopSubplan, Configuration) - Constructor for class org.apache.wayang.core.optimizer.cardinality.LoopSubplanCardinalityPusher
- LruCache<K,
V> - Class in org.apache.wayang.core.util -
Key-value cache with "least recently used" eviction strategy.
- LruCache(int) - Constructor for class org.apache.wayang.core.util.LruCache
M
- main(String[]) - Static method in class org.apache.wayang.api.sql.context.SqlContext
-
Entry point for executing SQL statements while providing arguments.
- main(String[]) - Static method in class org.apache.wayang.applications.WordCount
- main(String[]) - Static method in class org.apache.wayang.applications.WordCountOnKafkaTopic
- main(String...) - Static method in class org.apache.wayang.apps.grep.Grep
- main(String[]) - Static method in class org.apache.wayang.apps.pi.PiEstimation
- main(String[]) - Static method in class org.apache.wayang.apps.tpch.TPCHQ1WithJavaNative
- main(String[]) - Static method in class org.apache.wayang.apps.wordcount.Main
- main(String[]) - Static method in class org.apache.wayang.apps.wordcount.WordCount
- main(String[]) - Static method in class org.apache.wayang.apps.wordcount.WordCountParquet
- main(String[]) - Static method in class org.apache.wayang.apps.wordcount.WordCountWithJavaNativeAPI
- main(String...) - Static method in class org.apache.wayang.core.util.fs.S3FileSystem
- main(String[]) - Static method in class org.apache.wayang.ml4all.examples.RunKMeans
- main(String...) - Static method in class org.apache.wayang.ml4all.examples.RunSGD
- main(String[]) - Static method in class org.apache.wayang.profiler.hardware.DiskProfiler
- main(String[]) - Static method in class org.apache.wayang.profiler.java.Profiler
- main(String[]) - Static method in class org.apache.wayang.profiler.log.GeneticOptimizerApp
- main(String[]) - Static method in class org.apache.wayang.profiler.log.LogEvaluator
- main(String[]) - Static method in class org.apache.wayang.profiler.spark.Main
- Main - Class in org.apache.wayang.apps.wordcount
- Main - Class in org.apache.wayang.profiler.spark
-
Starts a profiling run of Spark.
- Main() - Constructor for class org.apache.wayang.apps.wordcount.Main
- Main() - Constructor for class org.apache.wayang.profiler.spark.Main
- makeCost() - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost.Factory
- makeCost() - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCostFactory
- map(InputType) - Method in class org.apache.wayang.flink.compiler.criterion.DummyMap
- map(Long) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator.RankAssigner
- map(List<S>, BiFunction<Integer, S, T>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Return a new
List
with mapped values. - map(List<S>, Function<S, T>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Return a new
List
with mapped values. - map(Tuple2<Long, Double>) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator.Dampener
- mapAllUpsteam(InputSlot<?>[], InputSlot<?>[]) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- mapAllUpsteam(OutputSlot<?>[], OutputSlot<?>[]) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- MapBasedKeyValueProvider<Key,
Value> - Class in org.apache.wayang.core.api.configuration -
Implementation of
KeyValueProvider
that uses aMap
to provide a value. - MapBasedKeyValueProvider(KeyValueProvider<Key, Value>) - Constructor for class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
-
Creates a new caching instance.
- MapBasedKeyValueProvider(KeyValueProvider<Key, Value>, boolean) - Constructor for class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
-
Creates a new instance.
- MapBasedKeyValueProvider(KeyValueProvider<Key, Value>, Configuration) - Constructor for class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
-
Creates a new caching instance.
- MapBasedKeyValueProvider(KeyValueProvider<Key, Value>, Configuration, boolean) - Constructor for class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
-
Creates a new instance.
- MapBasedKeyValueProvider(Configuration, boolean) - Constructor for class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
-
Creates a new instance.
- MapFunctionAdapter<InputType,
OutputType> - Class in org.apache.wayang.spark.compiler -
Wraps a
Function
as aFunction
. - MapFunctionAdapter(Function<InputType, OutputType>) - Constructor for class org.apache.wayang.spark.compiler.MapFunctionAdapter
- MapMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
MapOperator
toFlinkMapOperator
. - MapMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
MapOperator
toJavaMapOperator
. - MapMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
MapOperator
toSparkMapOperator
. - MapMapping() - Constructor for class org.apache.wayang.flink.mapping.MapMapping
- MapMapping() - Constructor for class org.apache.wayang.java.mapping.MapMapping
- MapMapping() - Constructor for class org.apache.wayang.spark.mapping.MapMapping
- MapOperator<InputType,
OutputType> - Class in org.apache.wayang.basic.operators -
A map operator represents semantics as they are known from frameworks, such as Spark and Flink.
- MapOperator(MapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapOperator
-
Copies an instance (exclusive of broadcasts).
- MapOperator(FunctionDescriptor.SerializableFunction<InputType, OutputType>, Class<InputType>, Class<OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapOperator
-
Creates a new instance.
- MapOperator(TransformationDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapOperator
-
Creates a new instance.
- MapOperator(TransformationDescriptor<InputType, OutputType>, DataSetType<InputType>, DataSetType<OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapOperator
-
Creates a new instance.
- MapPartitionsDescriptor<Input,
Output> - Class in org.apache.wayang.core.function -
This descriptor pertains to functions that consume and output multiple data quanta.
- MapPartitionsDescriptor(FunctionDescriptor.SerializableFunction<Iterable<Input>, Iterable<Output>>, Class<Input>, Class<Output>) - Constructor for class org.apache.wayang.core.function.MapPartitionsDescriptor
- MapPartitionsDescriptor(FunctionDescriptor.SerializableFunction<Iterable<Input>, Iterable<Output>>, Class<Input>, Class<Output>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.MapPartitionsDescriptor
- MapPartitionsDescriptor(FunctionDescriptor.SerializableFunction<Iterable<Input>, Iterable<Output>>, Class<Input>, Class<Output>, ProbabilisticDoubleInterval) - Constructor for class org.apache.wayang.core.function.MapPartitionsDescriptor
- MapPartitionsDescriptor(FunctionDescriptor.SerializableFunction<Iterable<Input>, Iterable<Output>>, Class<Input>, Class<Output>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.MapPartitionsDescriptor
- MapPartitionsDescriptor(FunctionDescriptor.SerializableFunction<Iterable<Input>, Iterable<Output>>, BasicDataUnitType<Input>, BasicDataUnitType<Output>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.MapPartitionsDescriptor
- MapPartitionsFunctionAdapter<InputType,
OutputType> - Class in org.apache.wayang.spark.compiler -
Wraps a
Function
as aFlatMapFunction
. - MapPartitionsFunctionAdapter(Function<Iterable<InputType>, Iterable<OutputType>>) - Constructor for class org.apache.wayang.spark.compiler.MapPartitionsFunctionAdapter
- MapPartitionsMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
MapPartitionsOperator
toFlinkMapPartitionsOperator
. - MapPartitionsMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
MapPartitionsOperator
toJavaMapPartitionsOperator
. - MapPartitionsMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
MapPartitionsOperator
toSparkMapPartitionsOperator
. - MapPartitionsMapping() - Constructor for class org.apache.wayang.flink.mapping.MapPartitionsMapping
- MapPartitionsMapping() - Constructor for class org.apache.wayang.java.mapping.MapPartitionsMapping
- MapPartitionsMapping() - Constructor for class org.apache.wayang.spark.mapping.MapPartitionsMapping
- MapPartitionsOperator<InputType,
OutputType> - Class in org.apache.wayang.basic.operators -
This operator takes as input potentially multiple input data quanta and outputs multiple input data quanta.
- MapPartitionsOperator(MapPartitionsOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapPartitionsOperator
-
Copies an instance (exclusive of broadcasts).
- MapPartitionsOperator(FunctionDescriptor.SerializableFunction<Iterable<InputType>, Iterable<OutputType>>, Class<InputType>, Class<OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapPartitionsOperator
-
Creates a new instance.
- MapPartitionsOperator(MapPartitionsDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapPartitionsOperator
-
Creates a new instance.
- MapPartitionsOperator(MapPartitionsDescriptor<InputType, OutputType>, DataSetType<InputType>, DataSetType<OutputType>) - Constructor for class org.apache.wayang.basic.operators.MapPartitionsOperator
-
Creates a new instance.
- Mapping - Interface in org.apache.wayang.core.mapping
-
A mapping issues a set of
PlanTransformation
s that make up the complete mapping. - Mappings - Class in org.apache.wayang.basic.mapping
-
Register for the components provided in the basic plugin.
- Mappings - Class in org.apache.wayang.flink.mapping
-
Register for
Mapping
s for this platform. - Mappings - Class in org.apache.wayang.genericjdbc.mapping
-
Register for the
Mapping
s supported for this platform. - Mappings - Class in org.apache.wayang.giraph.mappings
-
Register for
Mapping
s for this platform. - Mappings - Class in org.apache.wayang.iejoin.mapping
-
Mapping
s for theIEJoinOperator
. - Mappings - Class in org.apache.wayang.java.mapping
-
Register for
Mapping
s for this platform. - Mappings - Class in org.apache.wayang.postgres.mapping
-
Register for the
Mapping
s supported for this platform. - Mappings - Class in org.apache.wayang.spark.mapping
-
Register for
Mapping
s for this platform. - Mappings - Class in org.apache.wayang.sqlite3.mapping
-
Register for the
Mapping
s supported for this platform. - Mappings - Class in org.apache.wayang.tensorflow.mapping
-
Register for
Mapping
s for this platform. - Mappings() - Constructor for class org.apache.wayang.basic.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.flink.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.genericjdbc.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.giraph.mappings.Mappings
- Mappings() - Constructor for class org.apache.wayang.iejoin.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.java.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.postgres.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.spark.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.sqlite3.mapping.Mappings
- Mappings() - Constructor for class org.apache.wayang.tensorflow.mapping.Mappings
- MAPPINGS - Static variable in class org.apache.wayang.tensorflow.mapping.Mappings
- mapUpstream(InputSlot<?>, InputSlot<?>) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- mapUpstream(OutputSlot<?>, OutputSlot<?>) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- markAsExecuted() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- markAsExecuted() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- markAsExecuted() - Method in class org.apache.wayang.core.platform.lineage.ChannelLineageNode
- markAsExecuted() - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
-
Mark that this instance should not be traversed any more.
- markAsStartTask(ExecutionTask) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- markAsTerminalTask(ExecutionTask) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- markForInstrumentation() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- markProduced() - Method in class org.apache.wayang.core.platform.AbstractChannelInstance
- markProduced() - Method in interface org.apache.wayang.core.platform.ChannelInstance
-
Mark this instance as produced.
- markSupported() - Method in class org.apache.wayang.core.util.LimitedInputStream
- match(Operator) - Method in class org.apache.wayang.core.mapping.OperatorPattern
-
Test whether this pattern matches a given operator.
- match(WayangPlan, int) - Method in class org.apache.wayang.core.mapping.SubplanPattern
-
Match this pattern against a plan.
- MaterializedGroupByMapping - Class in org.apache.wayang.basic.mapping
-
This mapping translates the
GroupByOperator
into theMaterializedGroupByOperator
. - MaterializedGroupByMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
MaterializedGroupByOperator
toFlinkMaterializedGroupByOperator
. - MaterializedGroupByMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
MaterializedGroupByOperator
toJavaMaterializedGroupByOperator
. - MaterializedGroupByMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
MaterializedGroupByOperator
toSparkMaterializedGroupByOperator
. - MaterializedGroupByMapping() - Constructor for class org.apache.wayang.basic.mapping.MaterializedGroupByMapping
- MaterializedGroupByMapping() - Constructor for class org.apache.wayang.flink.mapping.MaterializedGroupByMapping
- MaterializedGroupByMapping() - Constructor for class org.apache.wayang.java.mapping.MaterializedGroupByMapping
- MaterializedGroupByMapping() - Constructor for class org.apache.wayang.spark.mapping.MaterializedGroupByMapping
- MaterializedGroupByOperator<Type,
Key> - Class in org.apache.wayang.basic.operators -
This operator collocates the data units in a data set w.r.t. a key function.
- MaterializedGroupByOperator(MaterializedGroupByOperator<Type, Key>) - Constructor for class org.apache.wayang.basic.operators.MaterializedGroupByOperator
-
Copies an instance (exclusive of broadcasts).
- MaterializedGroupByOperator(FunctionDescriptor.SerializableFunction<Type, Key>, Class<Type>, Class<Key>) - Constructor for class org.apache.wayang.basic.operators.MaterializedGroupByOperator
-
Creates a new instance.
- MaterializedGroupByOperator(TransformationDescriptor<Type, Key>) - Constructor for class org.apache.wayang.basic.operators.MaterializedGroupByOperator
-
Creates a new instance.
- MaterializedGroupByOperator(TransformationDescriptor<Type, Key>, DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.basic.operators.MaterializedGroupByOperator
-
Creates a new instance.
- MathExBaseListener - Class in org.apache.wayang.core.mathex
-
This class provides an empty implementation of
MathExListener
, which can be extended to create a listener which only needs to handle a subset of the available methods. - MathExBaseListener() - Constructor for class org.apache.wayang.core.mathex.MathExBaseListener
- MathExBaseVisitor<T> - Class in org.apache.wayang.core.mathex
-
This class provides an empty implementation of
MathExVisitor
, which can be extended to create a visitor which only needs to handle a subset of the available methods. - MathExBaseVisitor() - Constructor for class org.apache.wayang.core.mathex.MathExBaseVisitor
- MathExException - Exception in org.apache.wayang.core.util.mathex.exceptions
-
This exception signals a failed
Expression
evaluation. - MathExException() - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.MathExException
- MathExException(String) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.MathExException
- MathExException(String, Throwable) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.MathExException
- MathExException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.MathExException
- MathExException(Throwable) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.MathExException
- MathExLexer - Class in org.apache.wayang.core.mathex
- MathExLexer(CharStream) - Constructor for class org.apache.wayang.core.mathex.MathExLexer
- MathExListener - Interface in org.apache.wayang.core.mathex
-
This interface defines a complete listener for a parse tree produced by
MathExParser
. - MathExParser - Class in org.apache.wayang.core.mathex
- MathExParser(TokenStream) - Constructor for class org.apache.wayang.core.mathex.MathExParser
- MathExParser.BinaryOperationContext - Class in org.apache.wayang.core.mathex
- MathExParser.ConstantContext - Class in org.apache.wayang.core.mathex
- MathExParser.ExpressionContext - Class in org.apache.wayang.core.mathex
- MathExParser.FunctionContext - Class in org.apache.wayang.core.mathex
- MathExParser.ParensExpressionContext - Class in org.apache.wayang.core.mathex
- MathExParser.UnaryOperationContext - Class in org.apache.wayang.core.mathex
- MathExParser.VariableContext - Class in org.apache.wayang.core.mathex
- MathExVisitor<T> - Interface in org.apache.wayang.core.mathex
-
This interface defines a complete generic visitor for a parse tree produced by
MathExParser
. - MAX_SUPERSTEPS - Static variable in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm
-
Number of supersteps for this test
- maxIterations - Variable in class org.apache.wayang.ml4all.algorithms.sgd.SGDLoop
- maxSupersteps - Variable in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm
- Mean - Class in org.apache.wayang.basic.model.op
- Mean(int) - Constructor for class org.apache.wayang.basic.model.op.Mean
- Mean(int, String) - Constructor for class org.apache.wayang.basic.model.op.Mean
- Measurement - Class in org.apache.wayang.commons.util.profiledb.model
-
Measurement captures the value of a metric at a specific time
- Measurement() - Constructor for class org.apache.wayang.commons.util.profiledb.model.Measurement
-
Deserialization constructor.
- Measurement(String) - Constructor for class org.apache.wayang.commons.util.profiledb.model.Measurement
- MeasurementDeserializer - Class in org.apache.wayang.commons.util.profiledb.json
-
Custom deserializer for
Measurement
s Detects actual subclass of serialized instances and then delegates the deserialization to that subtype. - MeasurementDeserializer() - Constructor for class org.apache.wayang.commons.util.profiledb.json.MeasurementDeserializer
- MeasurementSerializer - Class in org.apache.wayang.commons.util.profiledb.json
-
Custom serializer for
Measurement
s Detects actual subclass of given instances, encodes this class membership, and then delegates serialization to that subtype. - MeasurementSerializer() - Constructor for class org.apache.wayang.commons.util.profiledb.json.MeasurementSerializer
- merge(ArrayList<Tuple2<Data<Type0, Type1>, Input>>, ArrayList<Tuple2<Data<Type0, Type1>, Input>>, boolean, boolean) - Method in class org.apache.wayang.iejoin.operators.java_helpers.BitSetJoin
- merge(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Merges
that
instance into this instance. - merge(Data[], Data[], boolean, boolean) - Method in class org.apache.wayang.iejoin.operators.spark_helpers.BitSetJoin
- mergeIntoOriginal() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Merges this instance into the original instance (
Channel.getOriginal()
. - mergeJunctionOptimizationContexts() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Merges the
OptimizationContext
s of theJunction
s in this instance into its mainOptimizationContext
/ - mergeToBase() - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
- mergeToBase() - Method in class org.apache.wayang.core.optimizer.DefaultOptimizationContext
- mergeToBase() - Method in class org.apache.wayang.core.optimizer.OptimizationContext
- MINIMUM - Static variable in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- ML_MAPPINGS - Static variable in class org.apache.wayang.spark.mapping.Mappings
- ml4allModel - Variable in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapperWithModel
- ML4allModel - Class in org.apache.wayang.ml4all.abstraction.plan
-
For keeping global variables to access in the logical operators.
- ML4allModel() - Constructor for class org.apache.wayang.ml4all.abstraction.plan.ML4allModel
- ML4allPlan - Class in org.apache.wayang.ml4all.abstraction.plan
-
Wayang physical plan for ML4all algorithms
- ML4allPlan() - Constructor for class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- mlPlugin() - Static method in class org.apache.wayang.spark.Spark
-
Retrieve the
SparkMLPlugin
. - mock(List<InputSlot<?>>, Operator, boolean) - Static method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- mock(List<OutputSlot<?>>, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
-
Copy the
OutputSlot
s to a givenOperator
. - mock(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- mock(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
-
Copy the
OutputSlot
s of a givenOperator
. - mock(Operator, Operator, boolean) - Static method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- model - Variable in class org.apache.wayang.basic.operators.DLTrainingOperator
- Model - Interface in org.apache.wayang.basic.model
-
A Type that represents a ML model
- Model(DecisionTreeClassificationModel) - Constructor for class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator.Model
- Model(LinearSVCModel) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator.Model
- Model(LogisticRegressionModel) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator.Model
- Model(KMeansModel) - Constructor for class org.apache.wayang.spark.operators.ml.SparkKMeansOperator.Model
- Model(DecisionTreeRegressionModel) - Constructor for class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator.Model
- Model(LinearRegressionModel) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator.Model
- modelEagerExecution(ChannelInstance[], ChannelInstance[], OptimizationContext.OperatorContext) - Static method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Models eager execution by marking all
LazyExecutionLineageNode
s as executed and collecting all marked ones. - modelLazyExecution(ChannelInstance[], ChannelInstance[], OptimizationContext.OperatorContext) - Static method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Models lazy execution by not marking any
LazyExecutionLineageNode
s. - ModelParser - Class in org.apache.wayang.api.sql.calcite.utils
- ModelParser() - Constructor for class org.apache.wayang.api.sql.calcite.utils.ModelParser
- ModelParser(Configuration) - Constructor for class org.apache.wayang.api.sql.calcite.utils.ModelParser
- ModelParser(Configuration, JsonNode) - Constructor for class org.apache.wayang.api.sql.calcite.utils.ModelParser
-
This method allows you to specify the Calcite path, useful for testing.
- ModelParser(Configuration, String) - Constructor for class org.apache.wayang.api.sql.calcite.utils.ModelParser
-
This method allows you to specify the Calcite path, useful for testing.
- modelQuasiEagerExecution(ChannelInstance[], ChannelInstance[], OptimizationContext.OperatorContext) - Static method in interface org.apache.wayang.core.plan.wayangplan.ExecutionOperator
-
Models eager execution by marking all
LazyExecutionLineageNode
s as executed and collecting all marked ones. - ModelTransformMapping - Class in org.apache.wayang.spark.mapping.ml
-
Deprecated.
- ModelTransformMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.ModelTransformMapping
-
Deprecated.
- ModelTransformOperator<X,
Y> - Class in org.apache.wayang.basic.operators -
Deprecated.
- ModelTransformOperator(TypeReference<X>, TypeReference<Tuple2<X, Y>>) - Constructor for class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- ModelTransformOperator(Class<X>, Class<Tuple2<X, Y>>) - Constructor for class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- ModelTransformOperator(ModelTransformOperator<X, Y>) - Constructor for class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- ModelTransformOperator(DataSetType<X>, DataSetType<Tuple2<X, Y>>) - Constructor for class org.apache.wayang.basic.operators.ModelTransformOperator
-
Deprecated.
- modeNames - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- momentum - Variable in class org.apache.wayang.basic.model.op.nn.BatchNorm
- Monitor - Class in org.apache.wayang.core.monitor
- Monitor() - Constructor for class org.apache.wayang.core.monitor.Monitor
- MONITOR_ENABLED_PROPERTY_KEY - Static variable in class org.apache.wayang.core.monitor.Monitor
- move(OperatorContainer, OperatorContainer) - Static method in class org.apache.wayang.core.plan.wayangplan.OperatorContainers
- MSELoss - Class in org.apache.wayang.basic.model.op.nn
- MSELoss() - Constructor for class org.apache.wayang.basic.model.op.nn.MSELoss
- MSELoss(String) - Constructor for class org.apache.wayang.basic.model.op.nn.MSELoss
- MultiConditionJoinFuncImpl - Class in org.apache.wayang.api.sql.calcite.converter.functions
-
Flattens Tuple2<Record, Record> to Record
- MultiConditionJoinFuncImpl() - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.MultiConditionJoinFuncImpl
- MultiConditionJoinKeyExtractor - Class in org.apache.wayang.api.sql.calcite.converter.functions
- MultiConditionJoinKeyExtractor(Integer...) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.MultiConditionJoinKeyExtractor
-
Extracts a key for a
WayangMultiConditionJoinVisitor
. - MultiMap<K,
V> - Class in org.apache.wayang.core.util -
Maps keys to multiple values.
- MultiMap() - Constructor for class org.apache.wayang.core.util.MultiMap
- mutate(double, Random) - Method in class org.apache.wayang.profiler.log.Variable
- mutate(Random, Bitmask, OptimizationSpace, double, double) - Method in class org.apache.wayang.profiler.log.Individual
- myMergeSort<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input> - Class in org.apache.wayang.iejoin.operators.java_helpers -
Created by khayyzy on 5/28/16.
- myMergeSort<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>> - Class in org.apache.wayang.iejoin.operators.spark_helpers -
Created by khayyzy on 5/28/16.
- myMergeSort() - Constructor for class org.apache.wayang.iejoin.operators.java_helpers.myMergeSort
- myMergeSort() - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.myMergeSort
N
- na() - Static method in class org.apache.wayang.core.util.Optional
-
Create a n/a instance.
- name - Variable in class org.apache.wayang.basic.model.op.Op
- name - Variable in class org.apache.wayang.basic.model.optimizer.Optimizer
- name - Variable in class org.apache.wayang.core.mathex.MathExParser.FunctionContext
- name(JavaPairRDD<?, ?>) - Method in interface org.apache.wayang.spark.operators.SparkExecutionOperator
-
Utility method to name an RDD according to this instance's name.
- name(JavaRDD<?>) - Method in interface org.apache.wayang.spark.operators.SparkExecutionOperator
-
Utility method to name an RDD according to this instance's name.
- NamedFunction - Class in org.apache.wayang.core.util.mathex.model
-
Expression
implementation that represents a function that is identified via its name. - NamedFunction(String, List<Expression>) - Constructor for class org.apache.wayang.core.util.mathex.model.NamedFunction
- NATIVE_BLOCK_SIZE - Static variable in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- ndArrayToTensor(NdArray<?>) - Static method in class org.apache.wayang.tensorflow.model.Convertor
- nest(LoadProfile) - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- nest(LoadProfileEstimator) - Method in class org.apache.wayang.core.optimizer.costs.ConstantLoadProfileEstimator
- nest(LoadProfileEstimator) - Method in interface org.apache.wayang.core.optimizer.costs.LoadProfileEstimator
-
Nest a sub-instance.
- nest(LoadProfileEstimator) - Method in class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
-
Nest a
LoadProfileEstimator
in this instance. - nest(LoadProfileEstimator) - Method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
- NestableLoadProfileEstimator - Class in org.apache.wayang.core.optimizer.costs
-
LoadProfileEstimator
that can host furtherLoadProfileEstimator
s. - NestableLoadProfileEstimator(LoadEstimator, LoadEstimator) - Constructor for class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
-
Creates an new instance.
- NestableLoadProfileEstimator(LoadEstimator, LoadEstimator, LoadEstimator, LoadEstimator) - Constructor for class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
-
Creates an new instance.
- NestableLoadProfileEstimator(LoadEstimator, LoadEstimator, LoadEstimator, LoadEstimator, FunctionDescriptor.SerializableToDoubleBiFunction<long[], long[]>, long) - Constructor for class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
-
Creates an new instance.
- NestableLoadProfileEstimator(LoadEstimator, LoadEstimator, LoadEstimator, LoadEstimator, FunctionDescriptor.SerializableToDoubleBiFunction<long[], long[]>, long, String) - Constructor for class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
-
Creates an new instance.
- nestUdfEstimator(Optional<LoadProfileEstimator>, FunctionDescriptor, Configuration) - Static method in class org.apache.wayang.core.optimizer.costs.LoadProfileEstimators
-
Utility to nest the
LoadProfileEstimator
of aFunctionDescriptor
. - networkConverter - Variable in class org.apache.wayang.core.optimizer.costs.LoadProfileToTimeConverter
- next() - Method in class org.apache.wayang.api.python.executor.ReaderIterator
- next() - Method in class org.apache.wayang.flink.operators.CollectionSplittableIterator
- next() - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator.ResultSetIterator
- nextSetBit(int) - Method in class org.apache.wayang.core.util.Bitmask
-
Finds the next set bit, starting from a given index.
- nextVertex() - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexReader
- NoInstrumentationStrategy - Class in org.apache.wayang.core.profiling
-
Instruments only outbound
Channel
s. - NoInstrumentationStrategy() - Constructor for class org.apache.wayang.core.profiling.NoInstrumentationStrategy
- NoIterationBreakpoint - Class in org.apache.wayang.core.platform
-
This
Breakpoint
implementation always requests a break unless inside ofExecutionStageLoop
s. - NoIterationBreakpoint() - Constructor for class org.apache.wayang.core.platform.NoIterationBreakpoint
- none() - Static method in class org.apache.wayang.core.types.DataSetType
-
Returns a null type.
- NONE - Static variable in interface org.apache.wayang.core.platform.Breakpoint
-
Breakpoint
implementation that never breaks. - NONE - Static variable in class org.apache.wayang.core.types.DataSetType
-
Stands for the absence of an actual instance.
- NOP - Static variable in interface org.apache.wayang.core.plan.wayangplan.PlanTraversal.Callback
-
Does nothing.
- normalize(CardinalityEstimate[], int) - Static method in interface org.apache.wayang.core.optimizer.costs.EstimationContext
-
Normalize the given estimates by dividing them by a number of executions.
- NoSuchKeyException(String) - Constructor for exception org.apache.wayang.core.api.configuration.KeyValueProvider.NoSuchKeyException
- NOT_STARTED - Enum constant in enum class org.apache.wayang.core.plan.wayangplan.LoopHeadOperator.State
-
The
LoopHeadOperator
has not been executed yet. - NotAvailableException(String) - Constructor for exception org.apache.wayang.core.api.configuration.ValueProvider.NotAvailableException
- noteDiscardedReference(boolean) - Method in class org.apache.wayang.core.util.AbstractReferenceCountable
- noteDiscardedReference(boolean) - Method in interface org.apache.wayang.core.util.ReferenceCountable
-
Declare that a reference on this instance has been discarded.
- noteObtainedReference() - Method in class org.apache.wayang.core.util.AbstractReferenceCountable
- noteObtainedReference() - Method in interface org.apache.wayang.core.util.ReferenceCountable
-
Declare that there is a new reference obtained on this instance.
- noteReplaced(Operator, Operator) - Method in interface org.apache.wayang.core.plan.wayangplan.CompositeOperator
-
Acknowledge that the given old operator has been replaced with a new one.
- noteReplaced(Operator, Operator) - Method in class org.apache.wayang.core.plan.wayangplan.LoopSubplan
- noteReplaced(Operator, Operator) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- noteReplaced(Operator, Operator) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- noteReplaced(Operator, OperatorContainer) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Acknowledge that the given old
Operator
has been replaced with anOperatorContainer
. - notifyDetached() - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Notifies this instance that it has been detached from its
InputSlot.occupant
. - NULL - Static variable in class org.apache.wayang.core.util.json.WayangJsonObj
- nullCardinalityReplacement - Variable in class org.apache.wayang.core.optimizer.costs.LoadEstimator
-
Should be used to replace
null
CardinalityEstimate
s. - NUMBER - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- NUMBER - Static variable in class org.apache.wayang.core.mathex.MathExParser
- NUMBER() - Method in class org.apache.wayang.core.mathex.MathExParser.ConstantContext
- numCoresPerMachine - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- numFeatures - Variable in class org.apache.wayang.basic.model.op.nn.BatchNorm
- numIterations - Variable in class org.apache.wayang.basic.operators.PageRankOperator
- numMachines - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- numPartitions - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
O
- OBJECT_FILE_TO_DATASET - Static variable in class org.apache.wayang.flink.channels.ChannelConversions
- ObjectFileSink<T> - Class in org.apache.wayang.basic.operators
-
This
UnarySink
writes all incoming data quanta to a Object file. - ObjectFileSink(String, Class<T>) - Constructor for class org.apache.wayang.basic.operators.ObjectFileSink
-
Creates a new instance.
- ObjectFileSink(String, DataSetType<T>) - Constructor for class org.apache.wayang.basic.operators.ObjectFileSink
-
Creates a new instance.
- ObjectFileSink(ObjectFileSink<T>) - Constructor for class org.apache.wayang.basic.operators.ObjectFileSink
-
Creates a copied instance.
- ObjectFileSinkMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
ObjectFileSink
toFlinkObjectFileSink
. - ObjectFileSinkMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
ObjectFileSink
toJavaObjectFileSink
. - ObjectFileSinkMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
ObjectFileSink
toSparkObjectFileSink
. - ObjectFileSinkMapping() - Constructor for class org.apache.wayang.flink.mapping.ObjectFileSinkMapping
- ObjectFileSinkMapping() - Constructor for class org.apache.wayang.java.mapping.ObjectFileSinkMapping
- ObjectFileSinkMapping() - Constructor for class org.apache.wayang.spark.mapping.ObjectFileSinkMapping
- ObjectFileSource<T> - Class in org.apache.wayang.basic.operators
-
This source reads a text file and outputs the lines as data units.
- ObjectFileSource(String, Class<T>) - Constructor for class org.apache.wayang.basic.operators.ObjectFileSource
- ObjectFileSource(String, DataSetType<T>) - Constructor for class org.apache.wayang.basic.operators.ObjectFileSource
- ObjectFileSource(ObjectFileSource) - Constructor for class org.apache.wayang.basic.operators.ObjectFileSource
-
Copies an instance (exclusive of broadcasts).
- ObjectFileSource.CardinalityEstimator - Class in org.apache.wayang.basic.operators
-
Custom
CardinalityEstimator
forFlatMapOperator
s. - ObjectFileSourceMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
ObjectFileSource
toFlinkObjectFileSource
. - ObjectFileSourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
ObjectFileSource
toJavaObjectFileSource
. - ObjectFileSourceMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
ObjectFileSource
toSparkObjectFileSource
. - ObjectFileSourceMapping() - Constructor for class org.apache.wayang.flink.mapping.ObjectFileSourceMapping
- ObjectFileSourceMapping() - Constructor for class org.apache.wayang.java.mapping.ObjectFileSourceMapping
- ObjectFileSourceMapping() - Constructor for class org.apache.wayang.spark.mapping.ObjectFileSourceMapping
- of(T) - Static method in class org.apache.wayang.core.util.Optional
-
Create a new instance with the given
value
. - ofExactly(double) - Static method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
-
Creates a new instance with a zero-width interval and a confidence of
1
. - OfSingleOperators(BiFunction<MatchedOperator, Integer, Operator>) - Constructor for class org.apache.wayang.core.mapping.ReplacementSubplanFactory.OfSingleOperators
-
Creates a new instance.
- onApplicationEnd(SparkListenerApplicationEnd) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called when the Spark application ends.
- onApplicationStart(SparkListenerApplicationStart) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called when a Spark application starts.
- OneTimeExecutable - Class in org.apache.wayang.core.util
-
Method wrapper that ensures that it is called only once.
- OneTimeExecutable() - Constructor for class org.apache.wayang.core.util.OneTimeExecutable
- onExecutorAdded(SparkListenerExecutorAdded) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
Overridden method that captures the event generated when an executor is added in Spark and sends it to the Kafka topic for further processing.
- onExecutorBlacklisted(SparkListenerExecutorBlacklisted) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
- onExecutorMetricsUpdate(SparkListenerExecutorMetricsUpdate) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called when metrics are updated for an executor in a Spark application, and it sends information about the updated executor to a Kafka topic.
- onExecutorRemoved(SparkListenerExecutorRemoved) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called when an executor is removed from a Spark application, and it sends information about the removal event to a Kafka topic.
- onJobEnd(SparkListenerJobEnd) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called when a job ends in the Spark application.
- onJobStart(SparkListenerJobStart) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called when a new Spark job starts.
- onStageCompleted(SparkListenerStageCompleted) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
Overrides the onStageCompleted method from SparkListener to customize handling of stage completion events.
- onStageSubmitted(SparkListenerStageSubmitted) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called whenever a new stage is submitted to the Spark engine.
- onTaskEnd(SparkListenerTaskEnd) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
Called when a SparkListenerTaskEnd event is triggered.
- onTaskGettingResult(SparkListenerTaskGettingResult) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
Called when a task's result is being fetched.
- onTaskStart(SparkListenerTaskStart) - Method in class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
This method is called when a task starts in a Spark application, and it creates a new TaskStart object with information about the task and adds it to a list of task objects for serializable.
- Op - Class in org.apache.wayang.basic.model.op
- Op(String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Op
- Op(Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Op
- Op.DType - Enum Class in org.apache.wayang.basic.model.op
- open(int, int) - Method in class org.apache.wayang.flink.compiler.OutputFormatConsumer
- open(int, int) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- open(String) - Method in interface org.apache.wayang.core.util.fs.FileSystem
-
Opens the file specified in the given
url
. - open(String) - Method in class org.apache.wayang.core.util.fs.HadoopFileSystem
- open(String) - Method in class org.apache.wayang.core.util.fs.LocalFileSystem
- open(String) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- open(String) - Static method in class org.apache.wayang.profiler.util.RrdAccessor
- open(Configuration) - Method in class org.apache.wayang.flink.compiler.criterion.WayangFilterCriterion
- open(Configuration) - Static method in class org.apache.wayang.core.profiling.ExecutionLog
-
Opens an instance according to the
Configuration
. - open(Configuration, String) - Static method in class org.apache.wayang.core.profiling.ExecutionLog
-
Opens an instance.
- open(ExecutionContext) - Method in class org.apache.wayang.basic.mapping.PageRankMapping.RankInitializer
- open(ExecutionContext) - Method in interface org.apache.wayang.core.function.ExtendedFunction
-
Called before this instance is actually executed.
- open(ExecutionContext) - Method in class org.apache.wayang.ml4all.abstraction.plan.wrappers.LogicalOperatorWrapperWithModel
- openFunction(JavaExecutionOperator, Object, ChannelInstance[], OptimizationContext.OperatorContext) - Static method in class org.apache.wayang.java.execution.JavaExecutor
-
Utility function to open an
ExtendedFunction
. - operand0 - Variable in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- operand1 - Variable in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- operator - Variable in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- operator - Variable in class org.apache.wayang.core.mathex.MathExParser.UnaryOperationContext
- operator - Variable in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activator
- operator - Variable in class org.apache.wayang.core.util.ExplainTreeNode
- operator - Variable in class org.apache.wayang.profiler.java.OperatorProfiler
- operator - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- Operator - Interface in org.apache.wayang.core.plan.wayangplan
-
An operator is any node that within a
WayangPlan
. - OperatorAlternative - Class in org.apache.wayang.core.plan.wayangplan
-
This operator encapsulates operators that are alternative to each other.
- OperatorAlternative() - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- OperatorAlternative(Operator) - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
-
Creates a new instance with the same number of inputs and outputs and the same parent as the given operator.
- OperatorAlternative.Alternative - Class in org.apache.wayang.core.plan.wayangplan
-
Represents an alternative subplan for the enclosing
OperatorAlternative
. - OperatorAlternativeCardinalityPusher - Class in org.apache.wayang.core.optimizer.cardinality
-
CardinalityPusher
implementation forOperatorAlternative
s. - OperatorAlternativeCardinalityPusher(OperatorAlternative, Configuration) - Constructor for class org.apache.wayang.core.optimizer.cardinality.OperatorAlternativeCardinalityPusher
- OperatorBase - Class in org.apache.wayang.core.plan.wayangplan
-
Helper class for the implementation of the
Operator
interface. - OperatorBase() - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorBase
- OperatorBase(int, int, boolean) - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorBase
- OperatorBase(InputSlot<?>[], OutputSlot<?>[], boolean) - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorBase
- OperatorBase(OperatorBase) - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorBase
-
Creates a plain copy of the given
OperatorBase
, including the number of regularInputSlot
s (not the actualInputSlot
s, though) the number ofOutputSlot
s (not the actualOutputSlot
s, though) whether broadcasts are supported any specificCardinalityEstimator
s - OperatorBase.GsonSerializer - Class in org.apache.wayang.core.plan.wayangplan
-
Utility to de/serialize
Operator
s. - OperatorContainer - Interface in org.apache.wayang.core.plan.wayangplan
-
This is not an
Operator
in its own right. - OperatorContainers - Class in org.apache.wayang.core.plan.wayangplan
-
Utilities to deal with
OperatorContainer
s. - OperatorContainers() - Constructor for class org.apache.wayang.core.plan.wayangplan.OperatorContainers
- OperatorContext(Operator) - Constructor for class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Creates a new instance.
- operatorGenerator - Variable in class org.apache.wayang.profiler.java.OperatorProfiler
- operatorGenerator - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- OperatorMatch - Class in org.apache.wayang.core.mapping
-
An operator match correlates an
OperatorPattern
to an actually matchedOperator
. - OperatorMatch(OperatorPattern, Operator) - Constructor for class org.apache.wayang.core.mapping.OperatorMatch
- OperatorNode(int, String, String, String) - Constructor for class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- OperatorPattern<T extends Operator> - Class in org.apache.wayang.core.mapping
-
An operator pattern matches to a class of operator instances.
- OperatorPattern(String, T, boolean) - Constructor for class org.apache.wayang.core.mapping.OperatorPattern
-
Creates a new instance.
- OperatorProfiler - Class in org.apache.wayang.profiler.java
-
Allows to instrument an
JavaExecutionOperator
. - OperatorProfiler(Supplier<JavaExecutionOperator>, Supplier<?>...) - Constructor for class org.apache.wayang.profiler.java.OperatorProfiler
- OperatorProfiler.Result - Class in org.apache.wayang.profiler.java
-
The result of a single profiling run.
- OperatorProfilers - Class in org.apache.wayang.profiler.java
-
Utilities to create
OperatorProfiler
instances. - OperatorProfilers - Class in org.apache.wayang.profiler.spark
-
Utilities to create
SparkOperatorProfiler
instances. - OperatorProfilers() - Constructor for class org.apache.wayang.profiler.java.OperatorProfilers
- OperatorProfilers() - Constructor for class org.apache.wayang.profiler.spark.OperatorProfilers
- Operators - Class in org.apache.wayang.core.plan.wayangplan
-
Utility class for
Operator
s. - Operators() - Constructor for class org.apache.wayang.core.plan.wayangplan.Operators
- OptimizationContext - Class in org.apache.wayang.core.optimizer
-
Manages contextual information required during the optimization of a
WayangPlan
. - OptimizationContext(Job) - Constructor for class org.apache.wayang.core.optimizer.OptimizationContext
-
Create a new, plain instance.
- OptimizationContext(Job, OptimizationContext, OptimizationContext.LoopContext, int, ChannelConversionGraph, List<PlanEnumerationPruningStrategy>) - Constructor for class org.apache.wayang.core.optimizer.OptimizationContext
-
Base constructor.
- OptimizationContext(Job, Operator) - Constructor for class org.apache.wayang.core.optimizer.OptimizationContext
-
Creates a new instance.
- OptimizationContext.LoopContext - Class in org.apache.wayang.core.optimizer
-
Maintains
OptimizationContext
s for the iterations of aLoopSubplan
. - OptimizationContext.OperatorContext - Class in org.apache.wayang.core.optimizer
-
Represents a single optimization context of an
Operator
. - OptimizationSpace - Class in org.apache.wayang.profiler.log
-
Context for the optimization of
LoadProfileEstimator
s. - OptimizationSpace() - Constructor for class org.apache.wayang.profiler.log.OptimizationSpace
- OptimizationUtils - Class in org.apache.wayang.core.optimizer
-
Utility methods for the optimization process.
- OptimizationUtils() - Constructor for class org.apache.wayang.core.optimizer.OptimizationUtils
- optimize(RelNode, RelTraitSet, RuleSet) - Method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- Optimizer - Class in org.apache.wayang.api.sql.calcite.optimizer
- Optimizer - Class in org.apache.wayang.basic.model.optimizer
- Optimizer(float) - Constructor for class org.apache.wayang.basic.model.optimizer.Optimizer
- Optimizer(float, String) - Constructor for class org.apache.wayang.basic.model.optimizer.Optimizer
- Optimizer(CalciteConnectionConfig, SqlValidator, SqlToRelConverter, VolcanoPlanner) - Constructor for class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- Optimizer.ConfigProperties - Class in org.apache.wayang.api.sql.calcite.optimizer
- option - Variable in class org.apache.wayang.basic.operators.DLTrainingOperator
- Option(Op, Optimizer, int, int) - Constructor for class org.apache.wayang.basic.operators.DLTrainingOperator.Option
- Optional<T> - Class in org.apache.wayang.core.util
-
Utility similar to
Optional
. - Optional() - Constructor for class org.apache.wayang.core.util.Optional
- optionalDouble(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- optionalDouble(String, double) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- optionallyProvide() - Method in class org.apache.wayang.core.api.configuration.ValueProvider
- optionallyProvideFor(Key) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
- optionalWayangJsonArray(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- optionalWayangJsonObj(String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- or(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Creates the new instance that merges this and the given one via logical OR.
- org.apache.wayang.api.python - package org.apache.wayang.api.python
- org.apache.wayang.api.python.executor - package org.apache.wayang.api.python.executor
- org.apache.wayang.api.python.function - package org.apache.wayang.api.python.function
- org.apache.wayang.api.sql.calcite.convention - package org.apache.wayang.api.sql.calcite.convention
- org.apache.wayang.api.sql.calcite.converter - package org.apache.wayang.api.sql.calcite.converter
- org.apache.wayang.api.sql.calcite.converter.functions - package org.apache.wayang.api.sql.calcite.converter.functions
- org.apache.wayang.api.sql.calcite.jdbc - package org.apache.wayang.api.sql.calcite.jdbc
- org.apache.wayang.api.sql.calcite.optimizer - package org.apache.wayang.api.sql.calcite.optimizer
- org.apache.wayang.api.sql.calcite.rel - package org.apache.wayang.api.sql.calcite.rel
- org.apache.wayang.api.sql.calcite.rules - package org.apache.wayang.api.sql.calcite.rules
- org.apache.wayang.api.sql.calcite.schema - package org.apache.wayang.api.sql.calcite.schema
- org.apache.wayang.api.sql.calcite.utils - package org.apache.wayang.api.sql.calcite.utils
- org.apache.wayang.api.sql.context - package org.apache.wayang.api.sql.context
- org.apache.wayang.api.sql.sources.fs - package org.apache.wayang.api.sql.sources.fs
- org.apache.wayang.applications - package org.apache.wayang.applications
- org.apache.wayang.apps.grep - package org.apache.wayang.apps.grep
- org.apache.wayang.apps.pi - package org.apache.wayang.apps.pi
- org.apache.wayang.apps.sgd - package org.apache.wayang.apps.sgd
- org.apache.wayang.apps.terasort - package org.apache.wayang.apps.terasort
- org.apache.wayang.apps.tpch - package org.apache.wayang.apps.tpch
- org.apache.wayang.apps.tpch.data - package org.apache.wayang.apps.tpch.data
- org.apache.wayang.apps.tpch.data.q1 - package org.apache.wayang.apps.tpch.data.q1
- org.apache.wayang.apps.wordcount - package org.apache.wayang.apps.wordcount
- org.apache.wayang.basic - package org.apache.wayang.basic
- org.apache.wayang.basic.channels - package org.apache.wayang.basic.channels
- org.apache.wayang.basic.data - package org.apache.wayang.basic.data
- org.apache.wayang.basic.function - package org.apache.wayang.basic.function
- org.apache.wayang.basic.mapping - package org.apache.wayang.basic.mapping
- org.apache.wayang.basic.model - package org.apache.wayang.basic.model
- org.apache.wayang.basic.model.op - package org.apache.wayang.basic.model.op
- org.apache.wayang.basic.model.op.nn - package org.apache.wayang.basic.model.op.nn
- org.apache.wayang.basic.model.optimizer - package org.apache.wayang.basic.model.optimizer
- org.apache.wayang.basic.operators - package org.apache.wayang.basic.operators
- org.apache.wayang.basic.plugin - package org.apache.wayang.basic.plugin
- org.apache.wayang.basic.types - package org.apache.wayang.basic.types
- org.apache.wayang.commons.util.profiledb - package org.apache.wayang.commons.util.profiledb
- org.apache.wayang.commons.util.profiledb.instrumentation - package org.apache.wayang.commons.util.profiledb.instrumentation
- org.apache.wayang.commons.util.profiledb.json - package org.apache.wayang.commons.util.profiledb.json
- org.apache.wayang.commons.util.profiledb.model - package org.apache.wayang.commons.util.profiledb.model
- org.apache.wayang.commons.util.profiledb.model.measurement - package org.apache.wayang.commons.util.profiledb.model.measurement
- org.apache.wayang.commons.util.profiledb.storage - package org.apache.wayang.commons.util.profiledb.storage
- org.apache.wayang.core.api - package org.apache.wayang.core.api
- org.apache.wayang.core.api.configuration - package org.apache.wayang.core.api.configuration
- org.apache.wayang.core.api.exception - package org.apache.wayang.core.api.exception
- org.apache.wayang.core.function - package org.apache.wayang.core.function
- org.apache.wayang.core.mapping - package org.apache.wayang.core.mapping
- org.apache.wayang.core.mathex - package org.apache.wayang.core.mathex
- org.apache.wayang.core.monitor - package org.apache.wayang.core.monitor
- org.apache.wayang.core.optimizer - package org.apache.wayang.core.optimizer
- org.apache.wayang.core.optimizer.cardinality - package org.apache.wayang.core.optimizer.cardinality
- org.apache.wayang.core.optimizer.channels - package org.apache.wayang.core.optimizer.channels
- org.apache.wayang.core.optimizer.costs - package org.apache.wayang.core.optimizer.costs
- org.apache.wayang.core.optimizer.enumeration - package org.apache.wayang.core.optimizer.enumeration
- org.apache.wayang.core.optimizer.partition - package org.apache.wayang.core.optimizer.partition
- org.apache.wayang.core.plan.executionplan - package org.apache.wayang.core.plan.executionplan
- org.apache.wayang.core.plan.wayangplan - package org.apache.wayang.core.plan.wayangplan
- org.apache.wayang.core.plan.wayangplan.traversal - package org.apache.wayang.core.plan.wayangplan.traversal
- org.apache.wayang.core.platform - package org.apache.wayang.core.platform
- org.apache.wayang.core.platform.lineage - package org.apache.wayang.core.platform.lineage
- org.apache.wayang.core.plugin - package org.apache.wayang.core.plugin
- org.apache.wayang.core.profiling - package org.apache.wayang.core.profiling
- org.apache.wayang.core.types - package org.apache.wayang.core.types
- org.apache.wayang.core.util - package org.apache.wayang.core.util
- org.apache.wayang.core.util.fs - package org.apache.wayang.core.util.fs
- org.apache.wayang.core.util.json - package org.apache.wayang.core.util.json
- org.apache.wayang.core.util.mathex - package org.apache.wayang.core.util.mathex
- org.apache.wayang.core.util.mathex.exceptions - package org.apache.wayang.core.util.mathex.exceptions
- org.apache.wayang.core.util.mathex.model - package org.apache.wayang.core.util.mathex.model
- org.apache.wayang.flink - package org.apache.wayang.flink
- org.apache.wayang.flink.channels - package org.apache.wayang.flink.channels
- org.apache.wayang.flink.compiler - package org.apache.wayang.flink.compiler
- org.apache.wayang.flink.compiler.criterion - package org.apache.wayang.flink.compiler.criterion
- org.apache.wayang.flink.execution - package org.apache.wayang.flink.execution
- org.apache.wayang.flink.mapping - package org.apache.wayang.flink.mapping
- org.apache.wayang.flink.operators - package org.apache.wayang.flink.operators
- org.apache.wayang.flink.platform - package org.apache.wayang.flink.platform
- org.apache.wayang.flink.plugin - package org.apache.wayang.flink.plugin
- org.apache.wayang.genericjdbc - package org.apache.wayang.genericjdbc
- org.apache.wayang.genericjdbc.channels - package org.apache.wayang.genericjdbc.channels
- org.apache.wayang.genericjdbc.execution - package org.apache.wayang.genericjdbc.execution
- org.apache.wayang.genericjdbc.mapping - package org.apache.wayang.genericjdbc.mapping
- org.apache.wayang.genericjdbc.operators - package org.apache.wayang.genericjdbc.operators
- org.apache.wayang.genericjdbc.platform - package org.apache.wayang.genericjdbc.platform
- org.apache.wayang.genericjdbc.plugin - package org.apache.wayang.genericjdbc.plugin
- org.apache.wayang.giraph - package org.apache.wayang.giraph
- org.apache.wayang.giraph.Algorithm - package org.apache.wayang.giraph.Algorithm
- org.apache.wayang.giraph.channels - package org.apache.wayang.giraph.channels
- org.apache.wayang.giraph.execution - package org.apache.wayang.giraph.execution
- org.apache.wayang.giraph.mappings - package org.apache.wayang.giraph.mappings
- org.apache.wayang.giraph.operators - package org.apache.wayang.giraph.operators
- org.apache.wayang.giraph.platform - package org.apache.wayang.giraph.platform
- org.apache.wayang.giraph.plugin - package org.apache.wayang.giraph.plugin
- org.apache.wayang.iejoin - package org.apache.wayang.iejoin
- org.apache.wayang.iejoin.data - package org.apache.wayang.iejoin.data
- org.apache.wayang.iejoin.mapping - package org.apache.wayang.iejoin.mapping
- org.apache.wayang.iejoin.mapping.java - package org.apache.wayang.iejoin.mapping.java
- org.apache.wayang.iejoin.mapping.spark - package org.apache.wayang.iejoin.mapping.spark
- org.apache.wayang.iejoin.operators - package org.apache.wayang.iejoin.operators
- org.apache.wayang.iejoin.operators.java_helpers - package org.apache.wayang.iejoin.operators.java_helpers
- org.apache.wayang.iejoin.operators.spark_helpers - package org.apache.wayang.iejoin.operators.spark_helpers
- org.apache.wayang.java - package org.apache.wayang.java
- org.apache.wayang.java.channels - package org.apache.wayang.java.channels
- org.apache.wayang.java.compiler - package org.apache.wayang.java.compiler
- org.apache.wayang.java.execution - package org.apache.wayang.java.execution
- org.apache.wayang.java.mapping - package org.apache.wayang.java.mapping
- org.apache.wayang.java.mapping.graph - package org.apache.wayang.java.mapping.graph
- org.apache.wayang.java.operators - package org.apache.wayang.java.operators
- org.apache.wayang.java.operators.graph - package org.apache.wayang.java.operators.graph
- org.apache.wayang.java.platform - package org.apache.wayang.java.platform
- org.apache.wayang.java.plugin - package org.apache.wayang.java.plugin
- org.apache.wayang.jdbc.channels - package org.apache.wayang.jdbc.channels
- org.apache.wayang.jdbc.compiler - package org.apache.wayang.jdbc.compiler
- org.apache.wayang.jdbc.execution - package org.apache.wayang.jdbc.execution
- org.apache.wayang.jdbc.operators - package org.apache.wayang.jdbc.operators
- org.apache.wayang.jdbc.platform - package org.apache.wayang.jdbc.platform
- org.apache.wayang.ml4all.abstraction.api - package org.apache.wayang.ml4all.abstraction.api
- org.apache.wayang.ml4all.abstraction.plan - package org.apache.wayang.ml4all.abstraction.plan
- org.apache.wayang.ml4all.abstraction.plan.wrappers - package org.apache.wayang.ml4all.abstraction.plan.wrappers
- org.apache.wayang.ml4all.algorithms.kmeans - package org.apache.wayang.ml4all.algorithms.kmeans
- org.apache.wayang.ml4all.algorithms.sgd - package org.apache.wayang.ml4all.algorithms.sgd
- org.apache.wayang.ml4all.examples - package org.apache.wayang.ml4all.examples
- org.apache.wayang.ml4all.utils - package org.apache.wayang.ml4all.utils
- org.apache.wayang.postgres - package org.apache.wayang.postgres
- org.apache.wayang.postgres.channels - package org.apache.wayang.postgres.channels
- org.apache.wayang.postgres.mapping - package org.apache.wayang.postgres.mapping
- org.apache.wayang.postgres.operators - package org.apache.wayang.postgres.operators
- org.apache.wayang.postgres.platform - package org.apache.wayang.postgres.platform
- org.apache.wayang.postgres.plugin - package org.apache.wayang.postgres.plugin
- org.apache.wayang.profiler.data - package org.apache.wayang.profiler.data
- org.apache.wayang.profiler.hardware - package org.apache.wayang.profiler.hardware
- org.apache.wayang.profiler.java - package org.apache.wayang.profiler.java
- org.apache.wayang.profiler.log - package org.apache.wayang.profiler.log
- org.apache.wayang.profiler.log.sampling - package org.apache.wayang.profiler.log.sampling
- org.apache.wayang.profiler.spark - package org.apache.wayang.profiler.spark
- org.apache.wayang.profiler.util - package org.apache.wayang.profiler.util
- org.apache.wayang.spark - package org.apache.wayang.spark
- org.apache.wayang.spark.channels - package org.apache.wayang.spark.channels
- org.apache.wayang.spark.compiler - package org.apache.wayang.spark.compiler
- org.apache.wayang.spark.execution - package org.apache.wayang.spark.execution
- org.apache.wayang.spark.mapping - package org.apache.wayang.spark.mapping
- org.apache.wayang.spark.mapping.graph - package org.apache.wayang.spark.mapping.graph
- org.apache.wayang.spark.mapping.ml - package org.apache.wayang.spark.mapping.ml
- org.apache.wayang.spark.model - package org.apache.wayang.spark.model
- org.apache.wayang.spark.monitoring.interfaces - package org.apache.wayang.spark.monitoring.interfaces
- org.apache.wayang.spark.monitoring.metrics - package org.apache.wayang.spark.monitoring.metrics
- org.apache.wayang.spark.operators - package org.apache.wayang.spark.operators
- org.apache.wayang.spark.operators.ml - package org.apache.wayang.spark.operators.ml
- org.apache.wayang.spark.platform - package org.apache.wayang.spark.platform
- org.apache.wayang.spark.plugin - package org.apache.wayang.spark.plugin
- org.apache.wayang.sqlite3 - package org.apache.wayang.sqlite3
- org.apache.wayang.sqlite3.channels - package org.apache.wayang.sqlite3.channels
- org.apache.wayang.sqlite3.mapping - package org.apache.wayang.sqlite3.mapping
- org.apache.wayang.sqlite3.operators - package org.apache.wayang.sqlite3.operators
- org.apache.wayang.sqlite3.platform - package org.apache.wayang.sqlite3.platform
- org.apache.wayang.sqlite3.plugin - package org.apache.wayang.sqlite3.plugin
- org.apache.wayang.tensorflow - package org.apache.wayang.tensorflow
- org.apache.wayang.tensorflow.channels - package org.apache.wayang.tensorflow.channels
- org.apache.wayang.tensorflow.execution - package org.apache.wayang.tensorflow.execution
- org.apache.wayang.tensorflow.mapping - package org.apache.wayang.tensorflow.mapping
- org.apache.wayang.tensorflow.model - package org.apache.wayang.tensorflow.model
- org.apache.wayang.tensorflow.model.op.nn - package org.apache.wayang.tensorflow.model.op.nn
- org.apache.wayang.tensorflow.operators - package org.apache.wayang.tensorflow.operators
- org.apache.wayang.tensorflow.platform - package org.apache.wayang.tensorflow.platform
- org.apache.wayang.tensorflow.plugin - package org.apache.wayang.tensorflow.plugin
- orInPlace(Bitmask) - Method in class org.apache.wayang.core.util.Bitmask
-
Accumulates the given instance to this one via logical OR.
- out - Variable in class org.apache.wayang.basic.model.DLModel
- OutboundInstrumentationStrategy - Class in org.apache.wayang.core.profiling
-
Instruments only outbound
Channel
s. - OutboundInstrumentationStrategy() - Constructor for class org.apache.wayang.core.profiling.OutboundInstrumentationStrategy
- outChannels - Variable in class org.apache.wayang.basic.model.op.nn.Conv
- outputConnectTo(Operator) - Method in class org.apache.wayang.basic.operators.LoopOperator
- outputConnectTo(Operator, int) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- outputConnectTo(Operator, int) - Method in class org.apache.wayang.basic.operators.LoopOperator
- outputFilePath - Variable in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
-
The path of the file to be written.
- OutputFormatConsumer<T> - Class in org.apache.wayang.flink.compiler
-
Wrapper for
- OutputFormatConsumer(FunctionDescriptor.SerializableConsumer<T>) - Constructor for class org.apache.wayang.flink.compiler.OutputFormatConsumer
- OutputSerializer - Class in org.apache.wayang.applications
- OutputSerializer() - Constructor for class org.apache.wayang.applications.OutputSerializer
- OutputSlot<T> - Class in org.apache.wayang.core.plan.wayangplan
-
An output slot declares an output of an
Operator
. - OutputSlot(String, Operator, DataSetType<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.OutputSlot
- OutputSlot(Slot<T>, Operator) - Constructor for class org.apache.wayang.core.plan.wayangplan.OutputSlot
- outputSlots - Variable in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- outputType - Variable in class org.apache.wayang.core.function.FlatMapDescriptor
- outputType - Variable in class org.apache.wayang.core.function.MapPartitionsDescriptor
- outputType - Variable in class org.apache.wayang.core.function.TransformationDescriptor
- outputTypeClass - Variable in class org.apache.wayang.flink.compiler.criterion.DummyMap
P
- padding - Variable in class org.apache.wayang.basic.model.op.nn.Conv
- PageRankAlgorithm - Class in org.apache.wayang.giraph.Algorithm
-
Basic PageRank implementation.
- PageRankAlgorithm() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm
- PageRankAlgorithm.PageRankMasterCompute - Class in org.apache.wayang.giraph.Algorithm
-
Master compute associated with
PageRankAlgorithm
. - PageRankAlgorithm.PageRankVertexInputFormat - Class in org.apache.wayang.giraph.Algorithm
-
Simple VertexInputFormat that supports
PageRankAlgorithm
- PageRankAlgorithm.PageRankVertexOutputFormat - Class in org.apache.wayang.giraph.Algorithm
-
Simple VertexOutputFormat that supports
PageRankAlgorithm
- PageRankAlgorithm.PageRankVertexOutputFormat.PageRankVertexWriter - Class in org.apache.wayang.giraph.Algorithm
-
Simple VertexWriter that supports
PageRankAlgorithm
- PageRankAlgorithm.PageRankVertexReader - Class in org.apache.wayang.giraph.Algorithm
-
Simple VertexReader that supports
PageRankAlgorithm
- PageRankAlgorithm.PageRankWorkerContext - Class in org.apache.wayang.giraph.Algorithm
-
Worker context used with
PageRankAlgorithm
. - PageRankMapping - Class in org.apache.wayang.basic.mapping
- PageRankMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
PageRankOperator
toFlinkPageRankOperator
. - PageRankMapping - Class in org.apache.wayang.giraph.mappings
-
Maps
PageRankOperator
s toGiraphPageRankOperator
s. - PageRankMapping - Class in org.apache.wayang.java.mapping.graph
-
Mapping from
PageRankOperator
toJavaPageRankOperator
. - PageRankMapping - Class in org.apache.wayang.spark.mapping.graph
-
Mapping from
PageRankOperator
to org.apache.wayang.spark.operators.graph.SparkPageRankOperator . - PageRankMapping() - Constructor for class org.apache.wayang.basic.mapping.PageRankMapping
- PageRankMapping() - Constructor for class org.apache.wayang.flink.mapping.PageRankMapping
- PageRankMapping() - Constructor for class org.apache.wayang.giraph.mappings.PageRankMapping
- PageRankMapping() - Constructor for class org.apache.wayang.java.mapping.graph.PageRankMapping
- PageRankMapping() - Constructor for class org.apache.wayang.spark.mapping.graph.PageRankMapping
- PageRankMapping.RankInitializer - Class in org.apache.wayang.basic.mapping
-
Creates intial page ranks.
- PageRankMasterCompute() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankMasterCompute
- PageRankOperator - Class in org.apache.wayang.basic.operators
-
Operator
for the PageRank algorithm. - PageRankOperator(Integer) - Constructor for class org.apache.wayang.basic.operators.PageRankOperator
-
Creates a new instance.
- PageRankOperator(Integer, Double, ProbabilisticDoubleInterval) - Constructor for class org.apache.wayang.basic.operators.PageRankOperator
-
Creates a new instance.
- PageRankOperator(PageRankOperator) - Constructor for class org.apache.wayang.basic.operators.PageRankOperator
-
Copies an instance (exclusive of broadcasts).
- PageRankParameters - Class in org.apache.wayang.giraph.Algorithm
-
Parameters for Basic PageRank implementation.
- PageRankParameters() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankParameters
- PageRankParameters.PageRankEnum - Enum Class in org.apache.wayang.giraph.Algorithm
- PageRankVertexInputFormat() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexInputFormat
- PageRankVertexOutputFormat() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexOutputFormat
- PageRankVertexReader() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexReader
- PageRankVertexWriter() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexOutputFormat.PageRankVertexWriter
- PageRankWorkerContext() - Constructor for class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- parameters - Variable in class org.apache.wayang.basic.operators.PyWayangReduceByOperator
- ParensExpressionContext(MathExParser.ExpressionContext) - Constructor for class org.apache.wayang.core.mathex.MathExParser.ParensExpressionContext
- parent - Variable in class org.apache.wayang.core.api.configuration.CollectionProvider
- parent - Variable in class org.apache.wayang.core.api.configuration.KeyValueProvider
- parent - Variable in class org.apache.wayang.core.api.configuration.ValueProvider
- ParquetSource - Class in org.apache.wayang.basic.operators
-
This source reads a parquet file and outputs the lines as
Record
units. - ParquetSource(String, String[], String...) - Constructor for class org.apache.wayang.basic.operators.ParquetSource
- ParquetSource(String, String[], DataSetType<Record>) - Constructor for class org.apache.wayang.basic.operators.ParquetSource
- ParquetSource(ParquetSource) - Constructor for class org.apache.wayang.basic.operators.ParquetSource
-
Copies an instance (exclusive of broadcasts).
- ParquetSource.CardinalityEstimator - Class in org.apache.wayang.basic.operators
-
Custom
CardinalityEstimator
forFlatMapOperator
s. - ParquetSourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
ParquetSource
toJavaParquetSource
. - ParquetSourceMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
CollectionSource
toSparkCollectionSource
. - ParquetSourceMapping() - Constructor for class org.apache.wayang.java.mapping.ParquetSourceMapping
- ParquetSourceMapping() - Constructor for class org.apache.wayang.spark.mapping.ParquetSourceMapping
- parse(String) - Method in class org.apache.wayang.apps.tpch.data.LineItemTuple.Parser
- parse(String) - Static method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
-
Parse the
specification
and construct anExpression
from it. - parseDate(String) - Static method in class org.apache.wayang.apps.tpch.data.LineItemTuple.Parser
- ParseException - Exception in org.apache.wayang.core.util.mathex.exceptions
-
This exception signals a failed
Expression
evaluation. - ParseException() - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.ParseException
- ParseException(String) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.ParseException
- ParseException(String, Throwable) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.ParseException
- ParseException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.ParseException
- ParseException(Throwable) - Constructor for exception org.apache.wayang.core.util.mathex.exceptions.ParseException
- parseLine(String) - Static method in class org.apache.wayang.api.sql.sources.fs.CsvRowConverter
- parseLine(String, char) - Static method in class org.apache.wayang.api.sql.sources.fs.CsvRowConverter
-
Parse line with a separator
- parsePlan(ExecutionPlan, boolean) - Static method in class org.apache.wayang.core.util.ExplainUtils
- parsePlan(WayangPlan, boolean) - Static method in class org.apache.wayang.core.util.ExplainUtils
- Parser() - Constructor for class org.apache.wayang.apps.tpch.data.LineItemTuple.Parser
- parseSql(String) - Method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- PartialExecution - Class in org.apache.wayang.core.platform
-
Captures data of a execution of a set of
ExecutionOperator
s. - PartialExecution(long, double, double, Collection<ExecutionLineageNode>, Configuration) - Constructor for class org.apache.wayang.core.platform.PartialExecution
-
Creates a new instance.
- PartialExecution.Serializer - Class in org.apache.wayang.core.platform
-
JsonSerializer
implementation forPartialExecution
s. - PartialExecutionMeasurement - Class in org.apache.wayang.core.profiling
-
This
Measurement
adapts aPartialExecutionMeasurement
. - PartialExecutionMeasurement(String, PartialExecution, Configuration) - Constructor for class org.apache.wayang.core.profiling.PartialExecutionMeasurement
-
Creates a new instance.
- partition(JavaRDD<T>) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
If a desired number of partitions for the input
JavaRDD
s is requested, enforce this. - permitsExecutionOf(ExecutionStage, ExecutionState, OptimizationContext) - Method in interface org.apache.wayang.core.platform.Breakpoint
-
Tests whether the given
ExecutionStage
can be executed. - permitsExecutionOf(ExecutionStage, ExecutionState, OptimizationContext) - Method in class org.apache.wayang.core.platform.CardinalityBreakpoint
- permitsExecutionOf(ExecutionStage, ExecutionState, OptimizationContext) - Method in class org.apache.wayang.core.platform.ConjunctiveBreakpoint
- permitsExecutionOf(ExecutionStage, ExecutionState, OptimizationContext) - Method in class org.apache.wayang.core.platform.FixBreakpoint
- permitsExecutionOf(ExecutionStage, ExecutionState, OptimizationContext) - Method in class org.apache.wayang.core.platform.NoIterationBreakpoint
- pickBestExecutionPlan(Collection<PlanImplementation>, ExecutionPlan, Set<Channel>, Set<ExecutionStage>) - Method in class org.apache.wayang.core.optimizer.costs.DefaultEstimatableCost
- pickBestExecutionPlan(Collection<PlanImplementation>, ExecutionPlan, Set<Channel>, Set<ExecutionStage>) - Method in interface org.apache.wayang.core.optimizer.costs.EstimatableCost
- pickCardinalities(OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.optimizer.cardinality.AbstractAlternativeCardinalityPusher
- PiEstimation - Class in org.apache.wayang.apps.pi
- PiEstimation() - Constructor for class org.apache.wayang.apps.pi.PiEstimation
- PlanEnumeration - Class in org.apache.wayang.core.optimizer.enumeration
-
Represents a collection of
PlanImplementation
s that all implement the same section of aWayangPlan
(which is assumed to containOperatorAlternative
s in general). - PlanEnumeration() - Constructor for class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
-
Creates a new instance.
- PlanEnumerationPruningStrategy - Interface in org.apache.wayang.core.optimizer.enumeration
-
A strategy to prune
PlanImplementation
s from aPlanEnumeration
. - PlanEnumerator - Class in org.apache.wayang.core.optimizer.enumeration
-
The plan partitioner recursively dissects a
WayangPlan
intoPlanEnumeration
s and then assembles them. - PlanEnumerator(WayangPlan, OptimizationContext) - Constructor for class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
-
Creates a new instance.
- PlanEnumerator(WayangPlan, OptimizationContext, ExecutionPlan, Set<Channel>) - Constructor for class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
-
Creates a new instance, thereby encorporating already executed parts of the
wayangPlan
. - PlanEnumerator.ConcatenationActivator - Class in org.apache.wayang.core.optimizer.enumeration
-
TODO.
- PlanEnumerator.EnumerationActivator - Class in org.apache.wayang.core.optimizer.enumeration
-
An
Operator
can be activated as soon as all of its inputs are available. - PlanImplementation - Class in org.apache.wayang.core.optimizer.enumeration
-
Represents a partial execution plan.
- PlanImplementation(PlanImplementation) - Constructor for class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
-
Copy constructor.
- PlanMetrics - Class in org.apache.wayang.core.plan.wayangplan
-
This class collects metrics for
WayangPlan
s. - PlanMetrics() - Constructor for class org.apache.wayang.core.plan.wayangplan.PlanMetrics
-
Serialization constructor.
- PlanTransformation - Class in org.apache.wayang.core.mapping
- PlanTransformation(SubplanPattern, ReplacementSubplanFactory, Platform...) - Constructor for class org.apache.wayang.core.mapping.PlanTransformation
- PlanTraversal - Class in org.apache.wayang.core.plan.wayangplan
-
Traverse a plan.
- PlanTraversal(boolean, boolean) - Constructor for class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Deprecated.
- PlanTraversal.Callback - Interface in org.apache.wayang.core.plan.wayangplan
-
A callback can be invoked during a plan traversal on each traversed node.
- PlanTraversal.SimpleCallback - Interface in org.apache.wayang.core.plan.wayangplan
-
A callback can be invoked during a plan traversal on each traversed node.
- platform() - Static method in class org.apache.wayang.flink.Flink
-
Retrieve the
FlinkPlatform
. - platform() - Static method in class org.apache.wayang.genericjdbc.GenericJdbc
-
Retrieve the
GenericJdbcPlatform
. - platform() - Static method in class org.apache.wayang.giraph.Giraph
-
Retrieve the
GiraphPlatform
. - platform() - Static method in class org.apache.wayang.java.Java
-
Retrieve the
JavaPlatform
. - platform() - Static method in class org.apache.wayang.postgres.Postgres
-
Retrieve the
PostgresPlatform
. - platform() - Static method in class org.apache.wayang.spark.Spark
-
Retrieve the
SparkPlatform
. - platform() - Static method in class org.apache.wayang.sqlite3.Sqlite3
-
Retrieve the
Sqlite3Platform
. - platform() - Static method in class org.apache.wayang.tensorflow.Tensorflow
-
Retrieve the
TensorflowPlatform
. - Platform - Class in org.apache.wayang.core.platform
-
A platform describes an execution engine that executes
ExecutionOperator
s. - Platform(String, String) - Constructor for class org.apache.wayang.core.platform.Platform
- PlatformExecution - Class in org.apache.wayang.core.plan.executionplan
-
Complete data flow on a single platform, that consists of multiple
ExecutionStage
s. - PlatformExecution(Platform) - Constructor for class org.apache.wayang.core.plan.executionplan.PlatformExecution
- Platforms - Enum Class in org.apache.wayang.ml4all.abstraction.plan
- plugin() - Static method in class org.apache.wayang.genericjdbc.GenericJdbc
-
Retrieve the
GenericJdbcPlugin
. - plugin() - Static method in class org.apache.wayang.giraph.Giraph
-
Retrieve the
GiraphPlugin
. - plugin() - Static method in class org.apache.wayang.iejoin.IEJoin
-
Retrieve a
Plugin
to useIEJoinOperator
andIESelfJoinOperator
on theJavaPlatform
andSparkPlatform
. - plugin() - Static method in class org.apache.wayang.postgres.Postgres
-
Retrieve the
PostgresPlugin
. - plugin() - Static method in class org.apache.wayang.sqlite3.Sqlite3
-
Retrieve the
Sqlite3Plugin
. - plugin() - Static method in class org.apache.wayang.tensorflow.Tensorflow
-
Retrieve the
TensorflowPlugin
. - Plugin - Interface in org.apache.wayang.core.plugin
-
A plugin contributes the following components to a
WayangContext
:Mapping
s,ChannelConversion
s, andConfiguration
properties. In turn, it may require severalPlatform
s for its operation. - plus(long) - Method in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- plus(CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
- plus(LoadEstimate) - Method in class org.apache.wayang.core.optimizer.costs.LoadEstimate
-
Adds a this and the given instance.
- plus(LoadProfile) - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
-
Adds a this and the given instance.
- plus(TimeEstimate) - Method in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- plus(ProbabilisticDoubleInterval) - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
-
Creates a new instance that represents the sum of the
this
andthat
instance. - postApplication() - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- Postgres - Class in org.apache.wayang.postgres
-
Register for relevant components of this module.
- Postgres() - Constructor for class org.apache.wayang.postgres.Postgres
- PostgresConversionsPlugin - Class in org.apache.wayang.postgres.plugin
- PostgresConversionsPlugin() - Constructor for class org.apache.wayang.postgres.plugin.PostgresConversionsPlugin
- PostgresExecutionOperator - Interface in org.apache.wayang.postgres.operators
- PostgresFilterOperator - Class in org.apache.wayang.postgres.operators
-
PostgreSQL implementation of the
FilterOperator
. - PostgresFilterOperator(FilterOperator<Record>) - Constructor for class org.apache.wayang.postgres.operators.PostgresFilterOperator
-
Copies an instance (exclusive of broadcasts).
- PostgresFilterOperator(PredicateDescriptor<Record>) - Constructor for class org.apache.wayang.postgres.operators.PostgresFilterOperator
-
Creates a new instance.
- PostgresJoinOperator<KeyType> - Class in org.apache.wayang.postgres.operators
-
PostgreSQL implementation of the
JoinOperator
. - PostgresJoinOperator(JoinOperator<Record, Record, KeyType>) - Constructor for class org.apache.wayang.postgres.operators.PostgresJoinOperator
- PostgresJoinOperator(TransformationDescriptor<Record, KeyType>, TransformationDescriptor<Record, KeyType>) - Constructor for class org.apache.wayang.postgres.operators.PostgresJoinOperator
-
Creates a new instance.
- PostgresPlatform - Class in org.apache.wayang.postgres.platform
-
Platform
implementation for SQLite3. - PostgresPlatform() - Constructor for class org.apache.wayang.postgres.platform.PostgresPlatform
- PostgresPlugin - Class in org.apache.wayang.postgres.plugin
- PostgresPlugin() - Constructor for class org.apache.wayang.postgres.plugin.PostgresPlugin
- PostgresProjectionOperator - Class in org.apache.wayang.postgres.operators
-
PostgreSQL implementation of the
FilterOperator
. - PostgresProjectionOperator(String...) - Constructor for class org.apache.wayang.postgres.operators.PostgresProjectionOperator
- PostgresProjectionOperator(ProjectionDescriptor<Record, Record>) - Constructor for class org.apache.wayang.postgres.operators.PostgresProjectionOperator
- PostgresProjectionOperator(MapOperator<Record, Record>) - Constructor for class org.apache.wayang.postgres.operators.PostgresProjectionOperator
- PostgresTableSource - Class in org.apache.wayang.postgres.operators
-
PostgreSQL implementation for the
TableSource
. - PostgresTableSource(String, String...) - Constructor for class org.apache.wayang.postgres.operators.PostgresTableSource
-
Creates a new instance.
- PostgresTableSource(JdbcTableSource) - Constructor for class org.apache.wayang.postgres.operators.PostgresTableSource
-
Copies an instance (exclusive of broadcasts).
- postSuperstep() - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- preApplication() - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- PREC0_OP - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- PREC0_OP - Static variable in class org.apache.wayang.core.mathex.MathExParser
- PREC1_OP - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- PREC1_OP - Static variable in class org.apache.wayang.core.mathex.MathExParser
- PREC2_OP - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- PREC2_OP - Static variable in class org.apache.wayang.core.mathex.MathExParser
- PREC2_OP() - Method in class org.apache.wayang.core.mathex.MathExParser.BinaryOperationContext
- PredicateAdapter<InputType> - Class in org.apache.wayang.spark.compiler
-
Wraps a
Predicate
as aFunction
. - PredicateAdapter(Predicate<InputType>) - Constructor for class org.apache.wayang.spark.compiler.PredicateAdapter
- predicateDescriptor - Variable in class org.apache.wayang.basic.operators.FilterOperator
-
Function that this operator applies to the input elements.
- PredicateDescriptor<Input> - Class in org.apache.wayang.core.function
-
This descriptor pertains to predicates that consume a single data unit.
- PredicateDescriptor(FunctionDescriptor.SerializablePredicate<Input>, Class<Input>) - Constructor for class org.apache.wayang.core.function.PredicateDescriptor
- PredicateDescriptor(FunctionDescriptor.SerializablePredicate<Input>, Class<Input>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.PredicateDescriptor
- PredicateDescriptor(FunctionDescriptor.SerializablePredicate<Input>, Class<Input>, ProbabilisticDoubleInterval) - Constructor for class org.apache.wayang.core.function.PredicateDescriptor
- PredicateDescriptor(FunctionDescriptor.SerializablePredicate<Input>, Class<Input>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.PredicateDescriptor
- PredicateDescriptor(FunctionDescriptor.SerializablePredicate<Input>, BasicDataUnitType<Input>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.PredicateDescriptor
- predict(double[]) - Method in interface org.apache.wayang.basic.model.DecisionTreeRegressionModel
-
Predict the output value for a single feature vector.
- predict(double[]) - Method in interface org.apache.wayang.basic.model.SVMModel
-
Predict the label for a given input vector.
- predict(double[]) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator.Model
- predict(double[]) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator.Model
- predict(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator.Model
- predict(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator.Model
- predict(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator.Model
- predict(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator.Model
- predict(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator.Model
- predict(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator.Model
- predict(JavaRDD<X>) - Method in interface org.apache.wayang.spark.model.SparkMLModel
- predict(XT) - Method in class org.apache.wayang.tensorflow.model.TensorflowModel
- PREDICTION - Static variable in class org.apache.wayang.spark.operators.ml.Attr
- PredictMapping - Class in org.apache.wayang.spark.mapping.ml
-
Mapping from
PredictOperator
toSparkPredictOperator
. - PredictMapping - Class in org.apache.wayang.tensorflow.mapping
-
Mapping from
PredictOperator
toTensorflowPredictOperator
. - PredictMapping() - Constructor for class org.apache.wayang.spark.mapping.ml.PredictMapping
- PredictMapping() - Constructor for class org.apache.wayang.tensorflow.mapping.PredictMapping
- PredictOperator<X,
Y> - Class in org.apache.wayang.basic.operators - PredictOperator(TypeReference<X>, TypeReference<Y>) - Constructor for class org.apache.wayang.basic.operators.PredictOperator
- PredictOperator(Class<X>, Class<Y>) - Constructor for class org.apache.wayang.basic.operators.PredictOperator
- PredictOperator(PredictOperator<X, Y>) - Constructor for class org.apache.wayang.basic.operators.PredictOperator
- PredictOperator(DataSetType<X>, DataSetType<Y>) - Constructor for class org.apache.wayang.basic.operators.PredictOperator
- PredictOperators - Class in org.apache.wayang.basic.operators
- PredictOperators() - Constructor for class org.apache.wayang.basic.operators.PredictOperators
- preFoldersExits(S3FileSystem.S3Pair) - Method in class org.apache.wayang.core.util.fs.S3FileSystem
- prepare() - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Prepares this
WayangPlan
for the optimization process if not already done. - prepare(long...) - Method in class org.apache.wayang.profiler.java.BinaryOperatorProfiler
- prepare(long...) - Method in class org.apache.wayang.profiler.java.OperatorProfiler
- prepare(long...) - Method in class org.apache.wayang.profiler.java.SinkProfiler
- prepare(long...) - Method in class org.apache.wayang.profiler.java.SourceProfiler
- prepare(long...) - Method in class org.apache.wayang.profiler.java.UnaryOperatorProfiler
- prepare(long...) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Call this method before
SparkOperatorProfiler.run()
to prepare the profiling run - prepare(ExecutionPlan, OptimizationContext) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
-
Clean up
ExecutionStage
-related state and re-createCrossPlatformExecutor.StageActivator
s etc. from theExecutionPlan
/ - prepareConvergenceDataset(double[], ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.sgd.SGDLoop
- prepareConvergenceDataset(ArrayList<Tuple2<Integer, double[]>>, ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.KMeansConvergeOrMaxIterationsLoop
- prepareConvergenceDataset(V, ML4allModel) - Method in class org.apache.wayang.ml4all.abstraction.api.Loop
- prepareInput(int, long) - Method in class org.apache.wayang.profiler.spark.BinaryOperatorProfiler
- prepareInput(int, long) - Method in class org.apache.wayang.profiler.spark.SinkProfiler
- prepareInput(int, long) - Method in class org.apache.wayang.profiler.spark.SparkCollectionSourceProfiler
- prepareInput(int, long) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- prepareInput(int, long) - Method in class org.apache.wayang.profiler.spark.SparkTextFileSourceProfiler
- prepareInput(int, long) - Method in class org.apache.wayang.profiler.spark.SparkUnaryOperatorProfiler
- prepareInputRdd(long, int) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Helper method to generate data quanta and provide them as a cached
JavaRDD
. - prepareInputRddInDriver(long, int) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Helper method to generate data quanta and provide them as a cached
JavaRDD
. - prepareInputRddInWorker(long, int) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Helper method to generate data quanta and provide them as a cached
JavaRDD
. - prepareVisit(Operator, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
- preSuperstep() - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankWorkerContext
- print() - Method in class org.apache.wayang.api.python.executor.ProcessReceiver
- print(String, RelNode) - Static method in class org.apache.wayang.api.sql.calcite.utils.PrintUtils
- print(String, WayangPlan) - Static method in class org.apache.wayang.api.sql.calcite.utils.PrintUtils
- printRecord(Record) - Static method in class org.apache.wayang.api.sql.calcite.utils.PrintUtils
- PrintUtils - Class in org.apache.wayang.api.sql.calcite.utils
- PrintUtils() - Constructor for class org.apache.wayang.api.sql.calcite.utils.PrintUtils
- ProbabilisticDoubleInterval - Class in org.apache.wayang.core.optimizer
-
An value representation that is capable of expressing uncertainty.
- ProbabilisticDoubleInterval() - Constructor for class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- ProbabilisticDoubleInterval(double, double, double) - Constructor for class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- ProbabilisticDoubleInterval(double, double, double, boolean) - Constructor for class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- ProbabilisticIntervalEstimate - Class in org.apache.wayang.core.optimizer
-
An estimate that is capable of expressing uncertainty.
- ProbabilisticIntervalEstimate() - Constructor for class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- ProbabilisticIntervalEstimate(long, long, double) - Constructor for class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- ProbabilisticIntervalEstimate(long, long, double, boolean) - Constructor for class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- proceed(Operator, int, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
- process(double[], ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.KMeansCompute
- process(double[], ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.sgd.ComputeLogisticGradient
- process(double[], ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.sgd.WeightsUpdate
- process(Queue<AbstractTopologicalTraversal.Activator<TActivation>>) - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activator
-
Execute this instance, thereby activating new instances and putting them on the queue.
- process(Tuple2<Integer, Tuple2<Integer, double[]>>, ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.KMeansUpdate
- process(Operator, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
- process(V, ML4allModel) - Method in class org.apache.wayang.ml4all.abstraction.api.Compute
-
Performs a computation at the data unit granularity
- process(V, ML4allModel) - Method in class org.apache.wayang.ml4all.abstraction.api.Update
-
Computes the new value of the global variable
- process(V, ML4allModel) - Method in class org.apache.wayang.ml4all.abstraction.api.UpdateLocal
-
Computes the new value of the global variable
- ProcessFeeder<Input,
Output> - Class in org.apache.wayang.api.python.executor - ProcessFeeder(Socket, ByteString, Iterable<Input>) - Constructor for class org.apache.wayang.api.python.executor.ProcessFeeder
- processParentEntry(Key, Value) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
-
React to a value that has been delivered by a
KeyValueProvider.parent
. - processParentEntry(Key, Value) - Method in class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
- ProcessReceiver<Output> - Class in org.apache.wayang.api.python.executor
- ProcessReceiver(Socket) - Constructor for class org.apache.wayang.api.python.executor.ProcessReceiver
- profile(int) - Method in class org.apache.wayang.profiler.hardware.DiskProfiler
-
Writes and reads a file and measures the elapsed time.
- ProfileDB - Class in org.apache.wayang.commons.util.profiledb
-
This class provides facilities to save and load
Experiment
s. - ProfileDB(Storage) - Constructor for class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Creates a new instance.
- ProfileDBs - Class in org.apache.wayang.core.profiling
-
Utilities to work with
ProfileDB
s. - ProfileDBs() - Constructor for class org.apache.wayang.core.profiling.ProfileDBs
- Profiler - Class in org.apache.wayang.profiler.java
-
Utility to support finding reasonable
LoadProfileEstimator
s forJavaExecutionOperator
s. - Profiler() - Constructor for class org.apache.wayang.profiler.java.Profiler
- ProfilingUtils - Class in org.apache.wayang.profiler.util
-
Utilities to fake Wayang internals etc..
- progress - Variable in class org.apache.wayang.core.monitor.Monitor
- progressUrl - Variable in class org.apache.wayang.core.monitor.Monitor
- ProjectionDescriptor<Input,
Output> - Class in org.apache.wayang.basic.function -
This descriptor pertains to projections.
- ProjectionDescriptor(Class<Input>, Class<Output>, String...) - Constructor for class org.apache.wayang.basic.function.ProjectionDescriptor
-
Creates a new instance.
- ProjectionDescriptor(BasicDataUnitType<Input>, BasicDataUnitType<Output>, String...) - Constructor for class org.apache.wayang.basic.function.ProjectionDescriptor
-
Creates a new instance.
- ProjectionMapping - Class in org.apache.wayang.genericjdbc.mapping
-
/** Mapping from
MapOperator
toGenericJdbcProjectionOperator
. - ProjectionMapping - Class in org.apache.wayang.postgres.mapping
-
/** Mapping from
MapOperator
toPostgresProjectionOperator
. - ProjectionMapping - Class in org.apache.wayang.sqlite3.mapping
-
Mapping from
MapOperator
toSqlite3ProjectionOperator
. - ProjectionMapping() - Constructor for class org.apache.wayang.genericjdbc.mapping.ProjectionMapping
- ProjectionMapping() - Constructor for class org.apache.wayang.postgres.mapping.ProjectionMapping
- ProjectionMapping() - Constructor for class org.apache.wayang.sqlite3.mapping.ProjectionMapping
- ProjectMapFuncImpl - Class in org.apache.wayang.api.sql.calcite.converter.functions
- ProjectMapFuncImpl(List<RexNode>) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.ProjectMapFuncImpl
- propagateInputCardinality(int, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Propagates the
CardinalityEstimate
of anInputSlot
within theoperatorContext
to inner, mappedInputSlot
s. - propagateInputCardinality(int, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- propagateInputCardinality(int, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- propagateInputCardinality(int, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
- propagateInputCardinality(int, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- propagateOutputCardinality(int, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Convenience version of
Operator.propagateOutputCardinality(int, OptimizationContext.OperatorContext)
, where the adjacentInputSlot
s reside in the sameOptimizationContext
as theoperatorContext
. - propagateOutputCardinality(int, OptimizationContext.OperatorContext) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
- propagateOutputCardinality(int, OptimizationContext.OperatorContext) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- propagateOutputCardinality(int, OptimizationContext.OperatorContext, OptimizationContext) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Propagates the
CardinalityEstimate
of anOutputSlot
within theoperatorContext
to fedInputSlot
s (which in turn are asked to propagate) and inner, mappedOutputSlot
s. - propagateOutputCardinality(int, OptimizationContext.OperatorContext, OptimizationContext) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- propagateOutputCardinality(int, OptimizationContext.OperatorContext, OptimizationContext) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- provide() - Method in class org.apache.wayang.core.api.configuration.ValueProvider
- provide(ValueProvider<Value>) - Method in class org.apache.wayang.core.api.configuration.ValueProvider
- provideAll() - Method in class org.apache.wayang.core.api.configuration.CollectionProvider
-
Provide all objects.
- provideAll(Configuration) - Method in class org.apache.wayang.core.api.configuration.CollectionProvider
-
Provide all objects.
- provideAll(Configuration) - Method in class org.apache.wayang.core.api.configuration.ExplicitCollectionProvider
- provideAll(Configuration) - Method in class org.apache.wayang.core.api.configuration.FunctionalCollectionProvider
- provideBroadcast() - Method in class org.apache.wayang.spark.channels.BroadcastChannel.Instance
- provideCollection() - Method in class org.apache.wayang.java.channels.CollectionChannel.Instance
- provideCpuCycles(long, long) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Estimates the disk bytes occurred in the cluster during the given time span by waiting for Ganglia to provide the respective information in its RRD files.
- provideDataSet() - Method in class org.apache.wayang.flink.channels.DataSetChannel.Instance
- provideDiskBytes() - Method in class org.apache.wayang.profiler.java.JavaTextFileSourceProfiler
- provideDiskBytes() - Method in class org.apache.wayang.profiler.java.OperatorProfiler
- provideDiskBytes(long, long) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Estimates the disk bytes occurred in the cluster during the given time span by waiting for Ganglia to provide the respective information in its RRD files.
- provideFor(Key) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
- provideFor(Key, KeyValueProvider<Key, Value>) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
- provideLocally(Key) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
-
Provide the value associated to the given key from this very instance, i.e., do not relay the request to parent instances on misses.
- provideNetworkBytes() - Method in class org.apache.wayang.profiler.java.OperatorProfiler
- provideNetworkBytes(long, long) - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Estimates the network bytes occurred in the cluster during the given time span by waiting for Ganglia to provide the respective information in its RRD files.
- provideRdd() - Method in class org.apache.wayang.spark.channels.RddChannel.Instance
- provideStream() - Method in class org.apache.wayang.java.channels.CollectionChannel.Instance
- provideStream() - Method in interface org.apache.wayang.java.channels.JavaChannelInstance
-
Provide the producer's result to a consumer.
- provideStream() - Method in class org.apache.wayang.java.channels.StreamChannel.Instance
- provideTensor() - Method in class org.apache.wayang.tensorflow.channels.TensorChannel.Instance
- prune() - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Prunes
Operator
s that do not (indirectly) contribute to a sink. - prune(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.LatentOperatorPruningStrategy
- prune(PlanEnumeration) - Method in interface org.apache.wayang.core.optimizer.enumeration.PlanEnumerationPruningStrategy
-
Prune down the
PlanEnumeration
, i.e., remove some of itsPlanImplementation
s. - prune(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.RandomPruningStrategy
- prune(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.SinglePlatformPruningStrategy
- prune(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.TopKPruningStrategy
- pureFlink(String, String) - Static method in class org.apache.wayang.apps.grep.Grep
- pureJava(String, String) - Static method in class org.apache.wayang.apps.grep.Grep
- pureSpark(String, String) - Static method in class org.apache.wayang.apps.grep.Grep
- push(Object) - Method in class org.apache.wayang.java.operators.JavaObjectFileSink.StreamChunker
-
Add a new element to the current chunk.
- push(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
- pushCardinalities() - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimatorManager
-
Traverse the
WayangPlan
, thereby updatingCardinalityEstimate
s. - pushCardinalities(PlanImplementation) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimatorManager
-
Traverse the
WayangPlan
, thereby updatingCardinalityEstimate
s. - pushCardinalitiesForward() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Push forward all marked
CardinalityEstimate
s within the sameOptimizationContext
. - pushCardinalityForward(int, OptimizationContext) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Pushes the
CardinalityEstimate
corresponding to theoutputIndex
forward to thetargetContext
if it is marked. - pushCardinalityUpdates(ExecutionState, PlanImplementation) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimatorManager
-
Injects the cardinalities of a current
ExecutionState
into its associatedWayangPlan
(or itsOptimizationContext
, respectively) and then reperforms the cardinality estimation. - PushExecutorTemplate - Class in org.apache.wayang.core.platform
-
Executor
implementation that employs a push model, i.e., data quanta are "pushed" through theExecutionStage
. - PushExecutorTemplate(Job) - Constructor for class org.apache.wayang.core.platform.PushExecutorTemplate
- PushExecutorTemplate.StageExecution - Class in org.apache.wayang.core.platform
-
Keeps track of state that is required within the execution of a single
ExecutionStage
. - pushThroughAlternatives(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.AbstractAlternativeCardinalityPusher
-
Do the pushing through all of the alternatives.
- pushThroughAlternatives(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.LoopHeadAlternativeCardinalityPusher
- pushThroughAlternatives(OptimizationContext.OperatorContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.OperatorAlternativeCardinalityPusher
- put(Object) - Method in class org.apache.wayang.core.util.json.WayangJsonArray
- put(String, double) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- put(String, int) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- put(String, long) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- put(String, Object) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- put(String, Object) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allModel
- put(String, String) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- put(String, WayangJsonArray) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- put(String, WayangJsonObj) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- put(Map<K, Collection<V>>, K, V) - Static method in class org.apache.wayang.core.util.WayangCollections
- put(WayangJsonObj) - Method in class org.apache.wayang.core.util.json.WayangJsonArray
- putIntoJobCache(String, Object) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Stores a value into the
Job
-global cache. - putJunction(OutputSlot<?>, Junction) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- putOptional(String, Object) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- putSingle(K, V) - Method in class org.apache.wayang.core.util.MultiMap
-
Associate a key with a new value.
- PythonAPI - Class in org.apache.wayang.api.python
- PythonAPI() - Constructor for class org.apache.wayang.api.python.PythonAPI
- PythonProcessCaller - Class in org.apache.wayang.api.python.executor
- PythonProcessCaller(ByteString) - Constructor for class org.apache.wayang.api.python.executor.PythonProcessCaller
- PythonWorkerManager<Input,
Output> - Class in org.apache.wayang.api.python.executor - PythonWorkerManager(ByteString, Iterable<Input>) - Constructor for class org.apache.wayang.api.python.executor.PythonWorkerManager
- PyWayangReduceByOperator<Type,
Key> - Class in org.apache.wayang.basic.operators - PyWayangReduceByOperator(Map<String, String>, ByteString, Class<Type>, Class<Type>, boolean) - Constructor for class org.apache.wayang.basic.operators.PyWayangReduceByOperator
- PyWayangReduceByOperator(Map<String, String>, ByteString, DataSetType<Type>, DataSetType<Type>, boolean) - Constructor for class org.apache.wayang.basic.operators.PyWayangReduceByOperator
- PyWayangReduceByOperator(PyWayangReduceByOperator<Type, Type>) - Constructor for class org.apache.wayang.basic.operators.PyWayangReduceByOperator
Q
- query(String, long, long, ConsolFun) - Method in class org.apache.wayang.profiler.util.RrdAccessor
- queryJobCache(String) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Queries the
Job
-global cache. - queryJobCache(String, Class<T>) - Method in class org.apache.wayang.core.optimizer.OptimizationContext
-
Queries the
Job
-global cache.
R
- RANDOM - Enum constant in enum class org.apache.wayang.basic.operators.SampleOperator.Methods
-
Randomly pick a sample.
- RandomPruningStrategy - Class in org.apache.wayang.core.optimizer.enumeration
- RandomPruningStrategy() - Constructor for class org.apache.wayang.core.optimizer.enumeration.RandomPruningStrategy
- randomSeed() - Static method in class org.apache.wayang.basic.operators.SampleOperator
-
Generate a random seed.
- RandomTreeSelectionStrategy() - Constructor for class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph.RandomTreeSelectionStrategy
- range(int) - Static method in class org.apache.wayang.core.util.WayangArrays
-
Enumerates in ascending order all integers
0 <= i < to
. - range(int, int) - Static method in class org.apache.wayang.core.util.WayangArrays
-
Enumerates in ascending order all integers
from <= i < to
. - RankAssigner(double) - Constructor for class org.apache.wayang.flink.operators.FlinkPageRankOperator.RankAssigner
- RankInitializer() - Constructor for class org.apache.wayang.basic.mapping.PageRankMapping.RankInitializer
- RddChannel - Class in org.apache.wayang.spark.channels
-
Describes the situation where one
JavaRDD
is operated on, producing a furtherJavaRDD
. - RddChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.spark.channels.RddChannel
- RddChannel.Instance - Class in org.apache.wayang.spark.channels
-
ChannelInstance
implementation forRddChannel
s. - read() - Method in class org.apache.wayang.core.util.LimitedInputStream
- read(byte[], int, int) - Method in class org.apache.wayang.core.util.LimitedInputStream
- read(Kryo, Input, Class<Product>) - Method in class org.apache.wayang.flink.operators.ScalaTupleSerializer
- read(DataInputView) - Method in class org.apache.wayang.flink.compiler.criterion.WayangValue
- ReaderIterator<Output> - Class in org.apache.wayang.api.python.executor
- ReaderIterator(DataInputStream) - Constructor for class org.apache.wayang.api.python.executor.ReaderIterator
- Record - Class in org.apache.wayang.basic.data
-
A Type that represents a record with a schema, might be replaced with something standard like JPA entity.
- Record(Object...) - Constructor for class org.apache.wayang.basic.data.Record
- Record(List<Object>) - Constructor for class org.apache.wayang.basic.data.Record
- RecordType - Class in org.apache.wayang.basic.types
-
This is a specific
BasicDataUnitType
forRecord
s. - RecordType(String...) - Constructor for class org.apache.wayang.basic.types.RecordType
-
Creates a new instance.
- recreateFrom(PlanImplementation, ExecutionPlan, Set<Channel>, Set<ExecutionStage>) - Static method in class org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow
- reduce(Iterable<Tuple2<Long, Long>>, Collector<Tuple2<Long, Long[]>>) - Method in class org.apache.wayang.flink.operators.FlinkPageRankOperator.BuildOutgoingEdgeList
- ReduceByMapping - Class in org.apache.wayang.basic.mapping
-
This mapping detects combinations of the
GroupByOperator
andReduceOperator
and merges them into a singleReduceByOperator
. - ReduceByMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
ReduceByOperator
toFlinkReduceByOperator
. - ReduceByMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
ReduceByOperator
toJavaReduceByOperator
. - ReduceByMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
ReduceByOperator
toSparkReduceByOperator
. - ReduceByMapping() - Constructor for class org.apache.wayang.basic.mapping.ReduceByMapping
- ReduceByMapping() - Constructor for class org.apache.wayang.flink.mapping.ReduceByMapping
- ReduceByMapping() - Constructor for class org.apache.wayang.java.mapping.ReduceByMapping
- ReduceByMapping() - Constructor for class org.apache.wayang.spark.mapping.ReduceByMapping
- ReduceByOperator<Type,
Key> - Class in org.apache.wayang.basic.operators -
This operator groups the elements of a data set and aggregates the groups.
- ReduceByOperator(ReduceByOperator<Type, Key>) - Constructor for class org.apache.wayang.basic.operators.ReduceByOperator
-
Copies an instance (exclusive of broadcasts).
- ReduceByOperator(FunctionDescriptor.SerializableFunction<Type, Key>, FunctionDescriptor.SerializableBinaryOperator<Type>, Class<Key>, Class<Type>) - Constructor for class org.apache.wayang.basic.operators.ReduceByOperator
-
Creates a new instance.
- ReduceByOperator(TransformationDescriptor<Type, Key>, ReduceDescriptor<Type>) - Constructor for class org.apache.wayang.basic.operators.ReduceByOperator
-
Creates a new instance.
- ReduceByOperator(TransformationDescriptor<Type, Key>, ReduceDescriptor<Type>, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.ReduceByOperator
-
Creates a new instance.
- reduceDescriptor - Variable in class org.apache.wayang.basic.operators.GlobalReduceOperator
- reduceDescriptor - Variable in class org.apache.wayang.basic.operators.PyWayangReduceByOperator
- reduceDescriptor - Variable in class org.apache.wayang.basic.operators.ReduceByOperator
- ReduceDescriptor<Type> - Class in org.apache.wayang.core.function
-
This descriptor pertains to functions that take multiple data units and aggregate them into a single data unit by means of a tree-like fold, i.e., using a commutative, associative function..
- ReduceDescriptor(FunctionDescriptor.SerializableBinaryOperator<Type>, Class<Type>) - Constructor for class org.apache.wayang.core.function.ReduceDescriptor
- ReduceDescriptor(FunctionDescriptor.SerializableBinaryOperator<Type>, DataUnitGroupType<Type>, BasicDataUnitType<Type>) - Constructor for class org.apache.wayang.core.function.ReduceDescriptor
- ReduceDescriptor(FunctionDescriptor.SerializableBinaryOperator<Type>, DataUnitGroupType<Type>, BasicDataUnitType<Type>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.ReduceDescriptor
- ReduceOperator<Type> - Class in org.apache.wayang.basic.operators
-
This operator is context dependent: after a
GroupByOperator
, it is meant to be aReduceByOperator
; otherwise, it is aGlobalReduceOperator
. - ReduceOperator(FunctionDescriptor.SerializableBinaryOperator<Type>, Class<Type>) - Constructor for class org.apache.wayang.basic.operators.ReduceOperator
-
Creates a new instance.
- ReduceOperator(ReduceDescriptor<Type>, DataSetType<Type>, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.ReduceOperator
-
Creates a new instance.
- Reducer(BinaryOperator<Type>) - Constructor for class org.apache.wayang.spark.compiler.FunctionCompiler.Reducer
- ReduceWrapper<T> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers
- ReduceWrapper() - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.ReduceWrapper
- ReferenceCountable - Interface in org.apache.wayang.core.util
-
This interface provides a reference-counting scheme, e.g., to manage allocated external resources.
- ReflectionUtils - Class in org.apache.wayang.core.util
-
Utilities for reflection code.
- ReflectionUtils() - Constructor for class org.apache.wayang.core.util.ReflectionUtils
- register(Class<? extends Measurement>) - Method in class org.apache.wayang.commons.util.profiledb.json.MeasurementDeserializer
- register(RelOptPlanner) - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- register(ExecutionTask) - Method in class org.apache.wayang.core.platform.Junction
-
Registers an
ExecutionTask
that participates in the instance. - register(ChannelInstance) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- register(ChannelInstance) - Method in interface org.apache.wayang.core.platform.ExecutionState
-
Register a
ChannelInstance
. - register(ExecutionResource) - Method in interface org.apache.wayang.core.platform.CompositeExecutionResource
-
Register a new
ExecutionResource
that is maintained by this instance. - register(ExecutionResource) - Method in class org.apache.wayang.core.platform.ExecutorTemplate
- register(Plugin) - Method in class org.apache.wayang.core.api.WayangContext
-
Registers the given
Plugin
with this instance. - registerGlobal(ExecutionResource) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
-
Register a global
ExecutionResource
, that will only be released once this instance has finished executing. - registerMeasuredCardinalities(Collection<ChannelInstance>) - Method in class org.apache.wayang.core.platform.ExecutorTemplate
-
Select the produced
ChannelInstance
s that are marked for instrumentation and register them if they contain a measured cardinality. - registerMeasuredCardinality(ChannelInstance) - Method in class org.apache.wayang.core.platform.ExecutorTemplate
-
If the given
ChannelInstance
has a measured cardinality, then register this cardinality in theExecutorTemplate.crossPlatformExecutor
with the correspondingChannel
and all its siblings. - registerMeasurementClass(Class<? extends Measurement>) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Register a
Measurement
type. - relevantInputIndices - Variable in class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
- relevantOutputIndices - Variable in class org.apache.wayang.core.optimizer.cardinality.CardinalityPusher
- ReLU - Class in org.apache.wayang.basic.model.op.nn
- ReLU() - Constructor for class org.apache.wayang.basic.model.op.nn.ReLU
- ReLU(String) - Constructor for class org.apache.wayang.basic.model.op.nn.ReLU
- remove(Object) - Method in class org.apache.wayang.core.util.Canonicalizer
- remove(T) - Method in class org.apache.wayang.core.util.Counter
- removeAll(Collection<?>) - Method in class org.apache.wayang.core.util.Canonicalizer
- removeEldestEntry(Map.Entry<K, V>) - Method in class org.apache.wayang.core.util.LruCache
- removeInputChannel(Channel) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
-
Removes the given
Channel
as input of this instance. - removeOutputChannel(Channel) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
-
Removes the given
Channel
as output of this instance. - removeSiblings() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Detaches this instance from all its
Channel.siblings
. - removeSiblingsWhere(Predicate<Channel>) - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Detaches this instance from all its
Channel.siblings
. - removeSingle(K, V) - Method in class org.apache.wayang.core.util.MultiMap
-
Disassociate a key with a value.
- RepeatMapping - Class in org.apache.wayang.basic.mapping
- RepeatMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
RepeatOperator
toFlinkRepeatOperator
. - RepeatMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
RepeatOperator
toJavaRepeatOperator
. - RepeatMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
RepeatOperator
toSparkRepeatOperator
. - RepeatMapping() - Constructor for class org.apache.wayang.basic.mapping.RepeatMapping
- RepeatMapping() - Constructor for class org.apache.wayang.flink.mapping.RepeatMapping
- RepeatMapping() - Constructor for class org.apache.wayang.java.mapping.RepeatMapping
- RepeatMapping() - Constructor for class org.apache.wayang.spark.mapping.RepeatMapping
- RepeatOperator<Type> - Class in org.apache.wayang.basic.operators
- RepeatOperator(Integer, Class<Type>) - Constructor for class org.apache.wayang.basic.operators.RepeatOperator
-
Creates a new instance.
- RepeatOperator(Integer, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.RepeatOperator
-
Creates a new instance.
- RepeatOperator(RepeatOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.RepeatOperator
-
Creates a copy of the given
RepeatOperator
. - replaceInputSlotMappings(Operator, Operator) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
-
Replace the mappings from an old, wrapped operator with a new wrapped operator.
- ReplacementSubplanFactory - Class in org.apache.wayang.core.mapping
-
This factory takes an
SubplanMatch
and derives a replacementSubplan
from it. - ReplacementSubplanFactory() - Constructor for class org.apache.wayang.core.mapping.ReplacementSubplanFactory
- ReplacementSubplanFactory.OfSingleOperators<MatchedOperator extends Operator> - Class in org.apache.wayang.core.mapping
-
Implementation of the
ReplacementSubplanFactory
that replaces exactly oneOperator
with exactly oneOperator
, where both have the exact sameInputSlot
s andOutputSlot
in the exact same order. - replaceNullCardinality(CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.costs.LoadEstimator
-
If the given
cardinalityEstimate
isnull
then returnLoadEstimator.nullCardinalityReplacement
, otherwisecardinalityEstimate
. - replaceOutputSlotMappings(Operator, Operator) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
-
Replace the mappings from an old, wrapped operator with a new wrapped operator.
- replaceSink(Operator, Operator) - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Replaces an
oldSink
with anewSink
. - replaceWith(Operator) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
- reportProgress(String, Integer) - Method in class org.apache.wayang.core.api.Job
- requireFileSystem(String) - Static method in class org.apache.wayang.core.util.fs.FileSystems
- RESERVOIR - Enum constant in enum class org.apache.wayang.basic.operators.SampleOperator.Methods
-
Reservoir sampling.
- ReservoirSampler<T> - Class in org.apache.wayang.profiler.log.sampling
-
Utility to do reservoir sampling with competitions over shared space.
- ReservoirSampler(int) - Constructor for class org.apache.wayang.profiler.log.sampling.ReservoirSampler
- reset() - Method in class org.apache.wayang.flink.compiler.criterion.WayangAggregator
- resetEstimates() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Resets the estimates of this instance.
- resetPivot() - Method in class org.apache.wayang.iejoin.data.Data
- Reshape - Class in org.apache.wayang.basic.model.op
- Reshape(int[]) - Constructor for class org.apache.wayang.basic.model.op.Reshape
- Reshape(int[], String) - Constructor for class org.apache.wayang.basic.model.op.Reshape
- Reshape(int[], String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Reshape
- Reshape(int[], Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Reshape
- resolveDownstream(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- resolveDownstream(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- resolveUpstream(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- resolveUpstream(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
- Result(List<Long>, long, long, long, long) - Constructor for class org.apache.wayang.profiler.java.OperatorProfiler.Result
- Result(List<Long>, long, long, long, long, long, int, int) - Constructor for class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- retain(Set<ExecutionStage>) - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Scrap any consumer
ExecutionTask
s and siblingChannel
s that are not within the givenExecutionStage
s. - retain(Set<ExecutionStage>) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
- retain(Set<ExecutionStage>) - Method in class org.apache.wayang.core.plan.executionplan.PlatformExecution
- retainAll(Collection<?>) - Method in class org.apache.wayang.core.util.Canonicalizer
- retainSuccessors(Set<ExecutionStage>) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- retrieveStaticVariable(String, String) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Retrieves a static variable.
- ReturnTuple - Class in org.apache.wayang.apps.tpch.data.q1
-
Tuple that is returned by Query 1.
- ReturnTuple() - Constructor for class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- ReturnTuple(char, char, double, double, double, double, double, double, double, int) - Constructor for class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- revDataComparator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input> - Class in org.apache.wayang.iejoin.operators.java_helpers - revDataComparator - Class in org.apache.wayang.iejoin.operators.spark_helpers
- revDataComparator(boolean, boolean, boolean) - Constructor for class org.apache.wayang.iejoin.operators.java_helpers.revDataComparator
- revDataComparator(boolean, boolean, boolean) - Constructor for class org.apache.wayang.iejoin.operators.spark_helpers.revDataComparator
- rounded(ToDoubleBiFunction<long[], long[]>) - Static method in class org.apache.wayang.core.optimizer.costs.DefaultLoadEstimator
-
Utility to create new instances: Rounds the results of a given estimation function.
- rounded(ToDoubleBiFunction<long[], long[]>) - Static method in class org.apache.wayang.core.optimizer.costs.IntervalLoadEstimator
-
Utility to create new instances: Rounds the results of a given estimation function.
- RrdAccessor - Class in org.apache.wayang.profiler.util
-
Utility to read from an RRD file.
- RULE_expression - Static variable in class org.apache.wayang.core.mathex.MathExParser
- ruleNames - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- ruleNames - Static variable in class org.apache.wayang.core.mathex.MathExParser
- run() - Method in class org.apache.wayang.profiler.java.OperatorProfiler
-
Executes and profiles the profiling task.
- run() - Method in class org.apache.wayang.profiler.log.GeneticOptimizerApp
- run() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
-
Executes and profiles the profiling task.
- run(RelOptPlanner, RelNode, RelTraitSet, List<RelOptMaterialization>, List<RelOptLattice>) - Method in class org.apache.wayang.api.sql.calcite.optimizer.WayangProgram
- runId - Variable in class org.apache.wayang.core.monitor.Monitor
- RunKMeans - Class in org.apache.wayang.ml4all.examples
- RunKMeans() - Constructor for class org.apache.wayang.ml4all.examples.RunKMeans
- RUNNING - Enum constant in enum class org.apache.wayang.core.plan.wayangplan.LoopHeadOperator.State
-
The
LoopHeadOperator
has been executed. - RUNNING - Enum constant in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
- RunSGD - Class in org.apache.wayang.ml4all.examples
- RunSGD() - Constructor for class org.apache.wayang.ml4all.examples.RunSGD
S
- S3FileSystem - Class in org.apache.wayang.core.util.fs
- S3FileSystem() - Constructor for class org.apache.wayang.core.util.fs.S3FileSystem
- sample(Collection<T>, Battle<T>, double) - Method in class org.apache.wayang.profiler.log.sampling.ReservoirSampler
- sample(Collection<T>, Battle<T>, double) - Method in interface org.apache.wayang.profiler.log.sampling.Sampler
-
Create a sample from a given
Collection
. - sample(Collection<T>, Battle<T>, double) - Method in class org.apache.wayang.profiler.log.sampling.TournamentSampler
- Sample - Class in org.apache.wayang.ml4all.abstraction.api
- Sample() - Constructor for class org.apache.wayang.ml4all.abstraction.api.Sample
- SampleMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
SampleOperator
toFlinkSampleOperator
. - SampleMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
SampleOperator
toJavaRandomSampleOperator
. - SampleMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
SampleOperator
toSparkRandomPartitionSampleOperator
. - SampleMapping() - Constructor for class org.apache.wayang.flink.mapping.SampleMapping
- SampleMapping() - Constructor for class org.apache.wayang.java.mapping.SampleMapping
- SampleMapping() - Constructor for class org.apache.wayang.spark.mapping.SampleMapping
- sampleMethod() - Method in class org.apache.wayang.ml4all.abstraction.api.Sample
- sampleMethod() - Method in class org.apache.wayang.ml4all.algorithms.sgd.SGDSample
- SampleOperator<Type> - Class in org.apache.wayang.basic.operators
-
A random sample operator randomly selects its inputs from the input slot and pushes that element to the output slot.
- SampleOperator(Integer, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.SampleOperator
-
Creates a new instance with any sampling method.
- SampleOperator(Integer, DataSetType<Type>, SampleOperator.Methods, long) - Constructor for class org.apache.wayang.basic.operators.SampleOperator
-
Creates a new instance given the sample size and the seed.
- SampleOperator(SampleOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.SampleOperator
-
Copies an instance (exclusive of broadcasts).
- SampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.SampleOperator
-
Creates a new instance with any sampling method.
- SampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, SampleOperator.Methods) - Constructor for class org.apache.wayang.basic.operators.SampleOperator
-
Creates a new instance given the sample size and the method.
- SampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, SampleOperator.Methods, long) - Constructor for class org.apache.wayang.basic.operators.SampleOperator
-
Creates a new instance given a user-defined sample size.
- SampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, SampleOperator.Methods, FunctionDescriptor.SerializableLongUnaryOperator) - Constructor for class org.apache.wayang.basic.operators.SampleOperator
-
Creates a new instance given user-defined sample size and seed methods.
- SampleOperator.Methods - Enum Class in org.apache.wayang.basic.operators
- Sampler<T> - Interface in org.apache.wayang.profiler.log.sampling
-
Interface that describes a sampling algorithm that can give bias towards certain elements..
- sampleSize() - Method in class org.apache.wayang.ml4all.abstraction.api.Sample
- sampleSize() - Method in class org.apache.wayang.ml4all.algorithms.sgd.SGDSample
- sampleSizeFunction - Variable in class org.apache.wayang.basic.operators.SampleOperator
-
This function determines the sample size by the number of iterations.
- SanityChecker - Class in org.apache.wayang.core.optimizer
-
This class checks a
WayangPlan
for several sanity criteria:Subplan
s must only be used as top-levelOperator
ofOperatorAlternative.Alternative
Subplan
s must contain more than oneOperator
- SanityChecker(WayangPlan) - Constructor for class org.apache.wayang.core.optimizer.SanityChecker
-
Create a new instance
- satisfies(RelTrait) - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- save(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Receive a Collection of
Experiment
s and persist them - save(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.storage.FileStorage
-
Write
Experiment
s to aFile
. - save(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.storage.JDBCStorage
-
Write
Experiment
s to aFile
. - save(Collection<Experiment>) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Receive a Collection of
Experiment
s and persist them - save(Collection<Experiment>, OutputStream) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Receive a Collection of
Experiment
s and persist them - save(Collection<Experiment>, OutputStream) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Write
Experiment
s to anOutputStream
. - save(Collection<Experiment>, Writer) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Write
Experiment
s to aWriter
. - save(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Receive an array of
Experiment
s and persist them - save(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.storage.FileStorage
-
Write
Experiment
s to aFile
. - save(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.storage.JDBCStorage
-
Write
Experiment
s to aFile
. - save(Experiment...) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Receive an array of
Experiment
s and persist them - sc - Variable in class org.apache.wayang.spark.execution.SparkExecutor
-
The
JavaSparkContext
to be used by this instance. - ScalaTupleSerializer - Class in org.apache.wayang.flink.operators
- ScalaTupleSerializer() - Constructor for class org.apache.wayang.flink.operators.ScalaTupleSerializer
- scan(DataContext) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- SchemaUtils - Class in org.apache.wayang.api.sql.calcite.schema
- SchemaUtils() - Constructor for class org.apache.wayang.api.sql.calcite.schema.SchemaUtils
- seed(long) - Method in class org.apache.wayang.ml4all.abstraction.api.Sample
- seed(long) - Method in class org.apache.wayang.ml4all.algorithms.sgd.SGDSample
- seedFunction - Variable in class org.apache.wayang.basic.operators.SampleOperator
-
This function optionally determines the seed by the number of iterations.
- select(ChannelConversionGraph.Tree, ChannelConversionGraph.Tree) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph.CostbasedTreeSelectionStrategy
- select(ChannelConversionGraph.Tree, ChannelConversionGraph.Tree) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversionGraph.RandomTreeSelectionStrategy
- sempred(RuleContext, int, int) - Method in class org.apache.wayang.core.mathex.MathExParser
- send() - Method in class org.apache.wayang.api.python.executor.ProcessFeeder
- SerializableObject - Interface in org.apache.wayang.spark.monitoring.interfaces
-
The
SerializableObject
interface is a marker interface that indicates that its implementing classes are serializable. - serialize(Object, boolean) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Try to serialize the given
Object
. - serialize(Measurement, Type, JsonSerializationContext) - Method in class org.apache.wayang.commons.util.profiledb.json.MeasurementSerializer
- serialize(Operator, Type, JsonSerializationContext) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase.GsonSerializer
- serialize(AtomicExecution) - Method in class org.apache.wayang.core.platform.AtomicExecution.KeyOrLoadSerializer
- serialize(AtomicExecutionGroup) - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup.Serializer
- serialize(PartialExecution) - Method in class org.apache.wayang.core.platform.PartialExecution.Serializer
- serialize(JsonSerializable, boolean) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Serialize the given
JsonSerializable
. - serialize(T) - Method in class org.apache.wayang.core.util.JsonSerializable.Serializer
- serialize(T) - Method in interface org.apache.wayang.core.util.JsonSerializer
-
Serializes an object.
- serialize(T, boolean, JsonSerializer<T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Serialize the given
Object
using a specificJsonSerializer
. - serializeAll(Collection<?>, boolean) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Try to serialize the given
Object
s. - serializeAll(Collection<T>, boolean, JsonSerializer<T>) - Static method in class org.apache.wayang.core.util.JsonSerializables
-
Serialize the given
Object
s using a specificJsonSerializer
. - Serializer() - Constructor for class org.apache.wayang.core.util.JsonSerializable.Serializer
- Serializer(Configuration) - Constructor for class org.apache.wayang.core.platform.AtomicExecutionGroup.Serializer
-
Creates a new instance.
- Serializer(Configuration) - Constructor for class org.apache.wayang.core.platform.PartialExecution.Serializer
-
Creates a new instance.
- set(int) - Method in class org.apache.wayang.core.util.Bitmask
-
Sets the bit at the given index.
- set(Key, Value) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
- set(Key, Value) - Method in class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
- setAccuracyCalculation(Op) - Method in class org.apache.wayang.basic.operators.DLTrainingOperator.Option
- setAppID(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Sets the ID of the application.
- setAppID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- setAppID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- setAuxiliary(boolean) - Method in interface org.apache.wayang.core.plan.wayangplan.ElementaryOperator
-
Tell whether this instance is auxiliary, i.e., it support some non-auxiliary operators.
- setAuxiliary(boolean) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- setBreakpoint(Breakpoint) - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
-
Set a new
Breakpoint
for this instance. - setBytesRead(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the number of bytes read by the task.
- setBytesRead(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setBytesWritten(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the number of bytes written by the task.
- setBytesWritten(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setCardinalityEstimate(CardinalityEstimate) - Method in class org.apache.wayang.core.plan.wayangplan.Slot
-
Deprecated.This method does not do anything, anymore.
- setCardinalityEstimator(int, CardinalityEstimator) - Method in interface org.apache.wayang.core.plan.wayangplan.ElementaryOperator
-
Tie a specific
CardinalityEstimator
to this instance. - setCardinalityEstimator(int, CardinalityEstimator) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
-
Tie a specific
CardinalityEstimator
to this instance. - setCardinalityEstimatorProvider(KeyValueProvider<OutputSlot<?>, CardinalityEstimator>) - Method in class org.apache.wayang.core.api.Configuration
- setChannelConversionProvider(ExplicitCollectionProvider<ChannelConversion>) - Method in class org.apache.wayang.core.api.Configuration
- setCollector(Collection<T>) - Method in class org.apache.wayang.basic.operators.LocalCallbackSink
- setCompletionTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the completion time of this stage.
- setCompletionTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setCompletionTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setCompletionTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setComputeOp(Compute) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setComputeOutput(Class, Class) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setContainer(OperatorContainer) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Operators can be nested in other operators, e.g., in a
Subplan
or aOperatorAlternative.Alternative
. - setContainer(OperatorContainer) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- setContext(ProfileDB) - Method in class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Sets the ProfileDB for this instance that manages all the Measurement subclasses
- setCostModel(EstimatableCost) - Method in class org.apache.wayang.core.api.Configuration
- setCostSquasherProvider(ValueProvider<ToDoubleFunction<ProbabilisticDoubleInterval>>) - Method in class org.apache.wayang.core.api.Configuration
- setDataQuantaType(String) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.ChannelNode
- setDatasetsize(long) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setDatasetSize(long) - Method in class org.apache.wayang.basic.operators.SampleOperator
- setDescription(String) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- setDestination(int) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.Link
- setDetails(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the details of this stage.
- setDetails(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setDetails(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setDetails(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setDiskBytesSpilled(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the number of bytes spilled to disk by the task.
- setDiskBytesSpilled(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setDoWhile(boolean) - Method in class org.apache.wayang.flink.compiler.criterion.WayangConvergenceCriterion
- setDurationTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the duration time of this task.
- setDurationTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setDurationTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setDurationTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setEnterJunction(Junction) - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- setEpoch(int) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Optional operation for non-composite operators.
- setEpoch(int) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- setEstimatedExecutionMillis(TimeEstimate) - Method in class org.apache.wayang.core.profiling.PartialExecutionMeasurement
- setEventame(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Sets the name of the event associated with the application.
- setEventame(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the name of the event associated with this executor.
- setEventame(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Sets the name of the event associated with this job.
- setEventame(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the name of the event associated with this stage.
- setEventame(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the name of the event associated with this task.
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setEventame(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setExecutionMillis(long) - Method in class org.apache.wayang.core.profiling.PartialExecutionMeasurement
- setExecutorCPUTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setExecutorDeserializeCpuTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the CPU time used for deserializing the task executor.
- setExecutorDeserializeCpuTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setExecutorDeserializeTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the time taken to deserialize the task executor.
- setExecutorDeserializeTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setExecutorHost(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the host where this executor is running.
- setExecutorHost(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- setExecutorHost(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- setExecutorHost(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- setExecutorID(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the ID of this executor.
- setExecutorID(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the ID of the executor associated with this stage.
- setExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- setExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- setExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- setExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setExecutorRunTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the total time taken by the task executor to run.
- setExecutorRunTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setExitJunction(Junction) - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- setField(int, Object) - Method in class org.apache.wayang.basic.data.Record
-
Set a field of this instance, at a given index.
- setField0(T0) - Method in class org.apache.wayang.core.util.Tuple
- setField1(T1) - Method in class org.apache.wayang.core.util.Tuple
- setFinishTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the finish time of this task.
- setFinishTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setFinishTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setFinishTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setForwardJunction(Junction) - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- setFunction(String, ToDoubleFunction<double[]>) - Method in class org.apache.wayang.core.util.mathex.DefaultContext
-
Register a function.
- setFunctionLoadProfileEstimatorProvider(KeyValueProvider<FunctionDescriptor, LoadProfileEstimator>) - Method in class org.apache.wayang.core.api.Configuration
- setGene(int, double, double) - Method in class org.apache.wayang.profiler.log.Individual
- setGettingTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the getting time of this task.
- setGettingTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setGettingTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setGettingTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setHostIP(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the IP address of the host machine executing this task.
- setHostIP(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setHostIP(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setHostIP(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setId(int) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.ChannelNode
- setId(int) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- setId(String) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- setId(String) - Method in class org.apache.wayang.commons.util.profiledb.model.Measurement
- setID(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the ID of this stage.
- setID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setID(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the ID of this task.
- setID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setIndex(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the index of this task.
- setIndex(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setIndex(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setIndex(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setIndices(int[]) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- setInput(int, InputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Sets the
InputSlot
of this instance. - setInputCardinality(int, CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Sets the
CardinalityEstimate
for a certainOutputSlot
. - setInstrumentationStrategyProvider(ValueProvider<InstrumentationStrategy>) - Method in class org.apache.wayang.core.api.Configuration
- setInterBodyJunction(Junction) - Method in class org.apache.wayang.core.optimizer.enumeration.LoopImplementation.IterationImplementation
- setJdbcName(String) - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Instance
- setJobID(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Sets the unique identifier for this job.
- setJobID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- setJobID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- setjvmGCTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the amount of time spent by the JVM on garbage collection.
- setjvmGCTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setLabel(double) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- setLaunchTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the launch time of this task.
- setLaunchTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setLaunchTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setLaunchTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setListOfJobs(List<Job>) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Sets the list of jobs associated with the application.
- setListOfJobs(List<Job>) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- setListOfJobs(List<Job>) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- setListOfStages(List<Stage>) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Sets the list of stages comprising this job.
- setListOfStages(List<Stage>) - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- setListOfStages(List<Stage>) - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- setListOfTasks(List<Task>) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the list of tasks to be performed.
- setListOfTasks(List<Task>) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setListOfTasks(List<Task>) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setListOfTasks(List<Task>) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setLoadEstimators(LoadEstimator, LoadEstimator) - Method in class org.apache.wayang.core.function.FunctionDescriptor
-
Deprecated.
- setLoadProfileEstimator(LoadProfileEstimator) - Method in class org.apache.wayang.core.function.FunctionDescriptor
- setLoadProfileEstimator(LoadProfileEstimator) - Method in class org.apache.wayang.core.platform.AtomicExecution
-
Change the
LoadProfileEstimator
encapsulated by this instance. - setLoadProfileEstimatorCache(MapBasedKeyValueProvider<String, LoadProfileEstimator>) - Method in class org.apache.wayang.core.api.Configuration
- setLoadProfileToTimeConverterProvider(KeyValueProvider<Platform, LoadProfileToTimeConverter>) - Method in class org.apache.wayang.core.api.Configuration
- setLocalStage(LocalStage) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setLogLevel(Level) - Method in class org.apache.wayang.core.api.WayangContext
- setLoopConvergeOutput(Class) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setLoopOp(Loop) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setLoopsIsolated() - Method in class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Tells that potential loops within this instance have been isolated.
- setLowerCost(double) - Method in class org.apache.wayang.core.profiling.CostMeasurement
- setMappingProvider(ExplicitCollectionProvider<Mapping>) - Method in class org.apache.wayang.core.api.Configuration
- setMeasuredCardinality(long) - Method in class org.apache.wayang.core.platform.AbstractChannelInstance
- setMeasuredCardinality(long) - Method in interface org.apache.wayang.core.platform.ChannelInstance
-
Register the measured cardinality with this instance.
- setMillis(long) - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
- setName(String) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Provide a name for this instance.
- setName(String) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- setName(String) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- setName(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Sets the name of the application.
- setName(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- setName(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- setNumberOfTasks(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the number of tasks associated with this stage.
- setNumberOfTasks(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setNumberOfTasks(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setNumberOfTasks(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setNumExecutions(int) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- setNumExpectedIterations(int) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- setNumExpectedIterations(int) - Method in class org.apache.wayang.basic.operators.LoopOperator
- setOperatorLoadProfileEstimatorProvider(KeyValueProvider<ExecutionOperator, LoadProfileEstimator>) - Method in class org.apache.wayang.core.api.Configuration
- setOutput(int, OutputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.Operator
-
Sets the
OutputSlot
of this instance. - setOutputCardinality(int, CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Sets the
CardinalityEstimate
for a certainInputSlot
. - setOutputChannel(int, Channel) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
-
Sets an output
Channel
for this instance. - setOutputDirectoryMode(FileOutputFormat.OutputDirectoryMode) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- setOutputFilePath(Path) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- setOverheadMillis(long) - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- setParameter(PageRankParameters.PageRankEnum, Integer) - Static method in class org.apache.wayang.giraph.Algorithm.PageRankParameters
- setParent(CollectionProvider<Value>) - Method in class org.apache.wayang.core.api.configuration.CollectionProvider
- setParent(KeyValueProvider<Key, Value>) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
- setParentContext(Context) - Method in class org.apache.wayang.core.util.mathex.DefaultContext
-
Set the parent context.
- setPartition(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the partition of this task.
- setPartition(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setPartition(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setPartition(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setPathOut(String, Configuration) - Method in class org.apache.wayang.giraph.operators.GiraphPageRankOperator
- setPeakExecutionMemory(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the peak execution memory used by the task executor.
- setPeakExecutionMemory(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setPlanEnumeration(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- setPlatform(String) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- setPlatformProvider(ExplicitCollectionProvider<Platform>) - Method in class org.apache.wayang.core.api.Configuration
- setPlatformStartUpTimeProvider(KeyValueProvider<Platform, Long>) - Method in class org.apache.wayang.core.api.Configuration
- setProbability(double) - Method in class org.apache.wayang.core.profiling.CostMeasurement
- setProductArity(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Sets the number of output products produced by this job.
- setProductArity(int) - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- setProductArity(int) - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- setProperties() - Method in class org.apache.wayang.api.sql.calcite.utils.ModelParser
- setProperties(Configuration) - Method in class org.apache.wayang.basic.plugin.WayangBasic
- setProperties(Configuration) - Method in class org.apache.wayang.basic.plugin.WayangBasicGraph
- setProperties(Configuration) - Method in class org.apache.wayang.core.plugin.DynamicPlugin
- setProperties(Configuration) - Method in interface org.apache.wayang.core.plugin.Plugin
-
Provides relevant
Configuration
properties. - setProperties(Configuration) - Method in class org.apache.wayang.flink.plugin.FlinkBasicPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.flink.plugin.FlinkConversionPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcConversionsPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.genericjdbc.plugin.GenericJdbcPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.giraph.plugin.GiraphPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.java.plugin.JavaBasicPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.java.plugin.JavaChannelConversionPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.java.plugin.JavaGraphPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.postgres.plugin.PostgresConversionsPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.postgres.plugin.PostgresPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.spark.plugin.SparkBasicPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.spark.plugin.SparkConversionPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.spark.plugin.SparkGraphPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.spark.plugin.SparkMLPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3ConversionPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.sqlite3.plugin.Sqlite3Plugin
- setProperties(Configuration) - Method in class org.apache.wayang.tensorflow.plugin.TensorflowConversionPlugin
- setProperties(Configuration) - Method in class org.apache.wayang.tensorflow.plugin.TensorflowPlugin
- setProperties(KeyValueProvider<String, String>) - Method in class org.apache.wayang.core.api.Configuration
- setProperty(String, String) - Method in class org.apache.wayang.core.api.Configuration
- setPruningStrategyClassProvider(CollectionProvider<Class<PlanEnumerationPruningStrategy>>) - Method in class org.apache.wayang.core.api.Configuration
- setRandomValue(Individual, Random) - Method in class org.apache.wayang.profiler.log.Variable
- setReasonOfRemoval(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the reason for which this executor was removed from the cluster.
- setReasonOfRemoval(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- setReasonOfRemoval(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- setReasonOfRemoval(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- setRecordsWritten(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the number of records written by the task.
- setRecordsWritten(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setResourceInfo(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the resource information of this executor.
- setResourceInfo(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- setResourceInfo(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- setResourceInfo(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- setResourceUtilization(double) - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- setResultSerializationTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the time taken to serialize the result of the task.
- setResultSerializationTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setResultSize(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.TaskMetric
-
Sets the size of the result produced by the task.
- setResultSize(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- setRichFunction(RichFunction) - Method in class org.apache.wayang.flink.execution.FlinkExecutionContext
- setRowID(long) - Method in class org.apache.wayang.iejoin.data.Data
- setSampleMethod(SampleOperator.Methods) - Method in class org.apache.wayang.basic.operators.SampleOperator
- setSampleOp(Sample) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setSeedFunction(FunctionDescriptor.SerializableLongUnaryOperator) - Method in class org.apache.wayang.basic.operators.SampleOperator
- setSink(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- setSink(Operator) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Set the sink.
- setSink(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- setSource(int) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.Link
- setSource(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- setSource(Operator) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Set the source.
- setSource(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- setSourceChannel(Channel) - Method in class org.apache.wayang.core.platform.Junction
- setSparkUser(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Sets the user associated with the Spark application.
- setSparkUser(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- setSparkUser(String) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- setSqlQuery(String) - Method in class org.apache.wayang.jdbc.channels.SqlQueryChannel.Instance
- setStage(ExecutionStage) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- setStageAttemptId(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the ID of the stage attempt.
- setStageAttemptId(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setStageAttemptId(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setStageAttemptId(int) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setStageID(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the ID of the stage the executor is running.
- setStageID(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the ID of the stage to which this task belongs.
- setStageID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- setStageID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- setStageID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- setStageID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setStageID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setStageID(int) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setStageID(Seq<Object>) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Job
-
Sets the stage ID associated with this job.
- setStageID(Seq<Object>) - Method in class org.apache.wayang.spark.monitoring.metrics.JobEnd
- setStageID(Seq<Object>) - Method in class org.apache.wayang.spark.monitoring.metrics.JobStart
- setStageName(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the name of this stage.
- setStageName(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setStageName(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setStageName(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setStartTime(long) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- setStartTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Application
-
Sets the start time of the application.
- setStartTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationEnd
- setStartTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.ApplicationStart
- setState(LoopHeadOperator.State) - Method in class org.apache.wayang.basic.operators.DoWhileOperator
- setState(LoopHeadOperator.State) - Method in class org.apache.wayang.basic.operators.LoopOperator
- setState(LoopHeadOperator.State) - Method in class org.apache.wayang.basic.operators.RepeatOperator
- setState(LoopHeadOperator.State) - Method in interface org.apache.wayang.core.plan.wayangplan.LoopHeadOperator
-
Optional operation.
- setStatus(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the status of this stage.
- setStatus(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setStatus(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setStatus(String) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setStringExecutorID(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the ID of the executor assigned to this task.
- setStringExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setStringExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setStringExecutorID(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setSubject(Subject) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- setSubmissionTime(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the submission time of this stage.
- setSubmissionTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setSubmissionTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setSubmissionTime(long) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setTags(Collection<String>) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- setTargetChannel(int, Channel) - Method in class org.apache.wayang.core.platform.Junction
- setTaskID(long) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the ID of this task.
- setTaskID(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setTaskID(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setTaskID(long) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setTaskMetric(TaskMetric) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Stage
-
Sets the task metric associated with this stage.
- setTaskMetric(TaskMetric) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the
TaskMetric
associated with this task. - setTaskMetric(TaskMetric) - Method in class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- setTaskMetric(TaskMetric) - Method in class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- setTaskMetric(TaskMetric) - Method in class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- setTaskMetric(TaskMetric) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setTaskMetric(TaskMetric) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setTaskMetric(TaskMetric) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setTaskStatus(boolean) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the status of this task.
- setTaskStatus(boolean) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setTaskStatus(boolean) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setTaskStatus(boolean) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setTaskStatus(String) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the status of this task.
- setTaskStatus(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setTaskStatus(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setTaskStatus(String) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setTaskStatusForRunning(Task.TaskStatusForRunning) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Task
-
Sets the task status for running.
- setTaskStatusForRunning(Task.TaskStatusForRunning) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- setTaskStatusForRunning(Task.TaskStatusForRunning) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- setTaskStatusForRunning(Task.TaskStatusForRunning) - Method in class org.apache.wayang.spark.monitoring.metrics.TaskStart
- setTimeMeasurement(TimeMeasurement) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator
-
Provide a
TimeMeasurement
allowing this instance to time internally. - setTimeToCostConverterProvider(KeyValueProvider<Platform, TimeToCostConverter>) - Method in class org.apache.wayang.core.api.Configuration
- setTotalCores(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the total number of cores available to this executor.
- setTotalCores(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- setTotalCores(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- setTotalCores(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- setTransformInput(Class) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setTransformOp(Transform) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setTransformOutput(Class) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setType(String) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.ChannelNode
- setType(String) - Method in class org.apache.wayang.core.profiling.ExecutionPlanMeasurement.OperatorNode
- setUdfSelectivityProvider(KeyValueProvider<FunctionDescriptor, ProbabilisticDoubleInterval>) - Method in class org.apache.wayang.core.api.Configuration
- setUpdateLocalOp(UpdateLocal) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setUpdateOp(Update) - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allPlan
- setUpOutput(ChannelDescriptor, Channel, OptimizationContext) - Method in interface org.apache.wayang.core.plan.executionplan.ChannelInitializer
-
Optional operation. Creates a new
Channel
incident* to thesource
. - setUpOutput(ChannelDescriptor, OutputSlot<?>, OptimizationContext) - Method in interface org.apache.wayang.core.plan.executionplan.ChannelInitializer
- setUpperCost(double) - Method in class org.apache.wayang.core.profiling.CostMeasurement
- setValue(Value) - Method in class org.apache.wayang.core.api.configuration.ConstantValueProvider
- setValues(double[]) - Method in class org.apache.wayang.ml4all.utils.SparseVector
- setVariable(String, double) - Method in class org.apache.wayang.core.util.mathex.DefaultContext
-
Register a variable.
- setWriteMode(FileSystem.WriteMode) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- SGDImpl - Class in org.apache.wayang.apps.sgd
-
This class executes a stochastic gradient descent optimization on Apache Wayang (incubating).
- SGDImpl(Configuration, Plugin[]) - Constructor for class org.apache.wayang.apps.sgd.SGDImpl
- SGDImprovedImpl - Class in org.apache.wayang.apps.sgd
-
This class executes a stochastic gradient descent optimization on Apache Wayang (incubating), just like
SGDImpl
. - SGDImprovedImpl(Configuration, Plugin[]) - Constructor for class org.apache.wayang.apps.sgd.SGDImprovedImpl
- SGDLoop - Class in org.apache.wayang.ml4all.algorithms.sgd
- SGDLoop(double, int) - Constructor for class org.apache.wayang.ml4all.algorithms.sgd.SGDLoop
- SGDSample - Class in org.apache.wayang.ml4all.algorithms.sgd
- SGDSample() - Constructor for class org.apache.wayang.ml4all.algorithms.sgd.SGDSample
- SGDStageWithZeros - Class in org.apache.wayang.ml4all.algorithms.sgd
- SGDStageWithZeros(int) - Constructor for class org.apache.wayang.ml4all.algorithms.sgd.SGDStageWithZeros
- shouldSplit(ExecutionTask, Channel, ExecutionTask) - Method in interface org.apache.wayang.core.optimizer.enumeration.StageAssignmentTraversal.StageSplittingCriterion
-
Tells whether two adjacent
ExecutionTask
s of the same currentStageAssignmentTraversal.InterimStage
should be placed in differentExecutionStage
s. - SHUFFLE_PARTITION_FIRST - Enum constant in enum class org.apache.wayang.basic.operators.SampleOperator.Methods
-
Shuffle a data partition first, then sequentially take the sample from this partition.
- shutdown() - Method in class org.apache.wayang.core.platform.CrossPlatformExecutor
- Sigmoid - Class in org.apache.wayang.basic.model.op.nn
- Sigmoid() - Constructor for class org.apache.wayang.basic.model.op.nn.Sigmoid
- Sigmoid(String) - Constructor for class org.apache.wayang.basic.model.op.nn.Sigmoid
- SimpleEstimationContext - Class in org.apache.wayang.core.optimizer.costs
-
This
EstimationContext
implementation just stores all required variables without any further logic. - SimpleEstimationContext(CardinalityEstimate[], CardinalityEstimate[], HashMap<String, Double>, int) - Constructor for class org.apache.wayang.core.optimizer.costs.SimpleEstimationContext
-
Creates a new instance.
- SinglePlatformPruningStrategy - Class in org.apache.wayang.core.optimizer.enumeration
-
This
PlanEnumerationPruningStrategy
retains only the bestPlanImplementation
s employing a singlePlatform
only. - SinglePlatformPruningStrategy() - Constructor for class org.apache.wayang.core.optimizer.enumeration.SinglePlatformPruningStrategy
- singleton(T, Class<T>) - Static method in class org.apache.wayang.basic.operators.CollectionSource
-
Creates a new instance without any data quanta.
- SinkProfiler - Class in org.apache.wayang.profiler.java
-
OperatorProfiler
implementation for sinks. - SinkProfiler - Class in org.apache.wayang.profiler.spark
-
SparkOperatorProfiler
implementation forSparkExecutionOperator
s with one input and no outputs. - SinkProfiler(Supplier<JavaExecutionOperator>, Supplier<?>...) - Constructor for class org.apache.wayang.profiler.java.SinkProfiler
- SinkProfiler(Supplier<SparkExecutionOperator>, Configuration, Supplier<?>) - Constructor for class org.apache.wayang.profiler.spark.SinkProfiler
- size() - Method in class org.apache.wayang.basic.data.Record
-
Retrieve the size of this instance.
- size() - Method in class org.apache.wayang.core.util.Canonicalizer
- size() - Method in class org.apache.wayang.ml4all.utils.SparseVector
- skip(long) - Method in class org.apache.wayang.core.util.LimitedInputStream
- sleep() - Method in class org.apache.wayang.core.profiling.CardinalityRepository
-
Allows this instance to free its system resources, as they might not be needed in the closer future.
- sleep(long) - Static method in class org.apache.wayang.profiler.util.ProfilingUtils
-
Puts the current
Thread
to sleep for a given number of milliseconds. - Slice - Class in org.apache.wayang.basic.model.op
- Slice(int[][]) - Constructor for class org.apache.wayang.basic.model.op.Slice
- Slice(int[][], String) - Constructor for class org.apache.wayang.basic.model.op.Slice
- Slice(int[][], String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Slice
- Slice(int[][], Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Slice
- Slot<T> - Class in org.apache.wayang.core.plan.wayangplan
-
Abstract class for inputs and outputs to operators.
- Slot() - Constructor for class org.apache.wayang.core.plan.wayangplan.Slot
- Slot(String, Operator, DataSetType<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.Slot
- slotlessOperator() - Static method in class org.apache.wayang.core.plan.wayangplan.Operators
- SlotMapping - Class in org.apache.wayang.core.plan.wayangplan
-
This mapping can be used to encapsulate subplans by connecting slots (usually against the data flow direction, i.e., outer output slot to inner output slot, inner input slot to outer input slot).
- SlotMapping() - Constructor for class org.apache.wayang.core.plan.wayangplan.SlotMapping
- snapshot(SchemaVersion) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- snapshot(SchemaVersion) - Method in class org.apache.wayang.api.sql.calcite.schema.WayangSchema
- Softmax - Class in org.apache.wayang.basic.model.op.nn
- Softmax() - Constructor for class org.apache.wayang.basic.model.op.nn.Softmax
- Softmax(String) - Constructor for class org.apache.wayang.basic.model.op.nn.Softmax
- sort(ArrayList<Tuple2<Data<Type0, Type1>, Input>>, int[], Comparator<Tuple2<Data<Type0, Type1>, Input>>) - Method in class org.apache.wayang.iejoin.operators.java_helpers.myMergeSort
- sort(Data[], int[], Comparator<Data>) - Static method in class org.apache.wayang.iejoin.operators.spark_helpers.myMergeSort
- SortFilter - Class in org.apache.wayang.api.sql.calcite.converter.functions
- SortFilter(int, int) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.SortFilter
-
The filter for a calcite/sql sort operator usually triggered by "LIMIT x", "OFFSET x", "FETCH x" statements
- SortKeyExtractor - Class in org.apache.wayang.api.sql.calcite.converter.functions
- SortKeyExtractor(List<RelFieldCollation.Direction>, List<Integer>) - Constructor for class org.apache.wayang.api.sql.calcite.converter.functions.SortKeyExtractor
- SortMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
SortOperator
toFlinkSortOperator
. - SortMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
SortOperator
toJavaSortOperator
. - SortMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
SortOperator
toSparkSortOperator
. - SortMapping() - Constructor for class org.apache.wayang.flink.mapping.SortMapping
- SortMapping() - Constructor for class org.apache.wayang.java.mapping.SortMapping
- SortMapping() - Constructor for class org.apache.wayang.spark.mapping.SortMapping
- SortOperator<Type,
Key> - Class in org.apache.wayang.basic.operators -
This operator sorts the elements in this dataset.
- SortOperator(SortOperator<Type, Key>) - Constructor for class org.apache.wayang.basic.operators.SortOperator
-
Copies an instance (exclusive of broadcasts).
- SortOperator(FunctionDescriptor.SerializableFunction<Type, Key>, Class<Type>, Class<Key>) - Constructor for class org.apache.wayang.basic.operators.SortOperator
-
Creates a new instance.
- SortOperator(TransformationDescriptor<Type, Key>) - Constructor for class org.apache.wayang.basic.operators.SortOperator
-
Creates a new instance.
- SortOperator(TransformationDescriptor<Type, Key>, DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.SortOperator
-
Creates a new instance.
- SourceProfiler - Class in org.apache.wayang.profiler.java
-
OperatorProfiler
implementation for sinks. - SourceProfiler(Supplier<JavaExecutionOperator>, Supplier<?>...) - Constructor for class org.apache.wayang.profiler.java.SourceProfiler
- Spark - Class in org.apache.wayang.spark
-
Register for relevant components of this module.
- Spark() - Constructor for class org.apache.wayang.spark.Spark
- SPARK - Enum constant in enum class org.apache.wayang.ml4all.abstraction.plan.Platforms
- SPARK_JAVA - Enum constant in enum class org.apache.wayang.ml4all.abstraction.plan.Platforms
- SPARK_PLUGIN - Static variable in class org.apache.wayang.iejoin.IEJoin
-
Enables use with the
SparkPlatform
. - SparkBasicPlugin - Class in org.apache.wayang.spark.plugin
- SparkBasicPlugin() - Constructor for class org.apache.wayang.spark.plugin.SparkBasicPlugin
- SparkBernoulliSampleOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
SparkBernoulliSampleOperator
. - SparkBernoulliSampleOperator(SampleOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
-
Copies an instance (exclusive of broadcasts).
- SparkBernoulliSampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, FunctionDescriptor.SerializableLongUnaryOperator) - Constructor for class org.apache.wayang.spark.operators.SparkBernoulliSampleOperator
-
Creates a new instance.
- SparkBroadcastOperator<Type> - Class in org.apache.wayang.spark.operators
-
Takes care of creating a
Broadcast
that can be used later on. - SparkBroadcastOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkBroadcastOperator
- SparkBroadcastOperator(SparkBroadcastOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkBroadcastOperator
- SparkCacheOperator<Type> - Class in org.apache.wayang.spark.operators
-
Converts an uncached
RddChannel
into a cachedRddChannel
. - SparkCacheOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkCacheOperator
- SparkCartesianOperator<InputType0,
InputType1> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
CartesianOperator
. - SparkCartesianOperator(CartesianOperator<InputType0, InputType1>) - Constructor for class org.apache.wayang.spark.operators.SparkCartesianOperator
-
Copies an instance (exclusive of broadcasts).
- SparkCartesianOperator(DataSetType<InputType0>, DataSetType<InputType1>) - Constructor for class org.apache.wayang.spark.operators.SparkCartesianOperator
-
Creates a new instance.
- SparkCoGroupOperator<In0,
In1, Key> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
JoinOperator
. - SparkCoGroupOperator(CoGroupOperator<In0, In1, Key>) - Constructor for class org.apache.wayang.spark.operators.SparkCoGroupOperator
- SparkCoGroupOperator(FunctionDescriptor.SerializableFunction<In0, Key>, FunctionDescriptor.SerializableFunction<In1, Key>, Class<In0>, Class<In1>, Class<Key>) - Constructor for class org.apache.wayang.spark.operators.SparkCoGroupOperator
- SparkCoGroupOperator(TransformationDescriptor<In0, Key>, TransformationDescriptor<In1, Key>) - Constructor for class org.apache.wayang.spark.operators.SparkCoGroupOperator
- SparkCoGroupOperator(TransformationDescriptor<In0, Key>, TransformationDescriptor<In1, Key>, DataSetType<In0>, DataSetType<In1>) - Constructor for class org.apache.wayang.spark.operators.SparkCoGroupOperator
- SparkCollectionSource<Type> - Class in org.apache.wayang.spark.operators
-
Provides a
Collection
to a Spark job. - SparkCollectionSource(Collection<Type>, DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkCollectionSource
-
Create a new instance to use a
collection
in aWayangPlan
. - SparkCollectionSource(CollectionSource) - Constructor for class org.apache.wayang.spark.operators.SparkCollectionSource
-
Copies an instance (exclusive of broadcasts).
- SparkCollectionSource(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkCollectionSource
-
Create a new instance to convert a
CollectionChannel
into aRddChannel
. - SparkCollectionSourceProfiler - Class in org.apache.wayang.profiler.spark
-
SparkOperatorProfiler
for theSparkTextFileSource
. - SparkCollectionSourceProfiler(Configuration, Supplier<T>, DataSetType<T>) - Constructor for class org.apache.wayang.profiler.spark.SparkCollectionSourceProfiler
- SparkCollectOperator<Type> - Class in org.apache.wayang.spark.operators
- SparkCollectOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkCollectOperator
- SparkContextReference - Class in org.apache.wayang.spark.execution
-
Wraps and manages a
JavaSparkContext
to avoid steady re-creation. - SparkContextReference(CrossPlatformExecutor, JavaSparkContext) - Constructor for class org.apache.wayang.spark.execution.SparkContextReference
-
Creates a new instance.
- SparkConversionPlugin - Class in org.apache.wayang.spark.plugin
-
This
Plugin
enables to createRDD
s. - SparkConversionPlugin() - Constructor for class org.apache.wayang.spark.plugin.SparkConversionPlugin
- SparkCountOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
CountOperator
. - SparkCountOperator(CountOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkCountOperator
-
Copies an instance (exclusive of broadcasts).
- SparkCountOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkCountOperator
-
Creates a new instance.
- SparkDecisionTreeClassificationOperator - Class in org.apache.wayang.spark.operators.ml
- SparkDecisionTreeClassificationOperator() - Constructor for class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator
- SparkDecisionTreeClassificationOperator(DecisionTreeClassificationOperator) - Constructor for class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator
- SparkDecisionTreeClassificationOperator.Model - Class in org.apache.wayang.spark.operators.ml
- SparkDecisionTreeRegressionOperator - Class in org.apache.wayang.spark.operators.ml
- SparkDecisionTreeRegressionOperator(int, int) - Constructor for class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator
- SparkDecisionTreeRegressionOperator(DecisionTreeRegressionOperator) - Constructor for class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator
- SparkDecisionTreeRegressionOperator.Model - Class in org.apache.wayang.spark.operators.ml
- SparkDistinctOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
DistinctOperator
. - SparkDistinctOperator(DistinctOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkDistinctOperator
-
Copies an instance (exclusive of broadcasts).
- SparkDistinctOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkDistinctOperator
-
Creates a new instance.
- SparkDoWhileOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
DoWhileOperator
. - SparkDoWhileOperator(DoWhileOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.spark.operators.SparkDoWhileOperator
-
Creates a new instance.
- SparkDoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.spark.operators.SparkDoWhileOperator
-
Creates a new instance.
- SparkDoWhileOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.spark.operators.SparkDoWhileOperator
- SparkExecutionContext - Class in org.apache.wayang.spark.execution
-
ExecutionContext
implementation for theSparkPlatform
. - SparkExecutionContext(int) - Constructor for class org.apache.wayang.spark.execution.SparkExecutionContext
-
Creates a new instance.
- SparkExecutionContext(SparkExecutionOperator, ChannelInstance[], int) - Constructor for class org.apache.wayang.spark.execution.SparkExecutionContext
-
Creates a new instance.
- SparkExecutionOperator - Interface in org.apache.wayang.spark.operators
-
Execution operator for the
SparkPlatform
. - sparkExecutor - Variable in class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- SparkExecutor - Class in org.apache.wayang.spark.execution
-
Executor
implementation for theSparkPlatform
. - SparkExecutor(SparkPlatform, Job) - Constructor for class org.apache.wayang.spark.execution.SparkExecutor
- SparkFilterOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
FilterOperator
. - SparkFilterOperator(FilterOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkFilterOperator
-
Copies an instance (exclusive of broadcasts).
- SparkFilterOperator(DataSetType<Type>, PredicateDescriptor<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkFilterOperator
-
Creates a new instance.
- SparkFlatMapOperator<InputType,
OutputType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
FlatMapOperator
. - SparkFlatMapOperator(FlatMapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.spark.operators.SparkFlatMapOperator
-
Copies an instance (exclusive of broadcasts).
- SparkFlatMapOperator(DataSetType, DataSetType, FlatMapDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.spark.operators.SparkFlatMapOperator
-
Creates a new instance.
- SparkGlobalMaterializedGroupOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
GlobalMaterializedGroupOperator
. - SparkGlobalMaterializedGroupOperator(Class<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- SparkGlobalMaterializedGroupOperator(GlobalMaterializedGroupOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
-
Copies an instance (exclusive of broadcasts).
- SparkGlobalMaterializedGroupOperator(DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.spark.operators.SparkGlobalMaterializedGroupOperator
- SparkGlobalReduceOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
GlobalReduceOperator
. - SparkGlobalReduceOperator(GlobalReduceOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
-
Copies an instance (exclusive of broadcasts).
- SparkGlobalReduceOperator(DataSetType<Type>, ReduceDescriptor<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkGlobalReduceOperator
-
Creates a new instance.
- SparkGraphPlugin - Class in org.apache.wayang.spark.plugin
- SparkGraphPlugin() - Constructor for class org.apache.wayang.spark.plugin.SparkGraphPlugin
- SparkIEJoinOperator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input extends Copyable<Input>> - Class in org.apache.wayang.iejoin.operators -
Spark implementation of the
IEJoinOperator
. - SparkIEJoinOperator(DataSetType<Input>, DataSetType<Input>, TransformationDescriptor<Input, Type0>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.SparkIEJoinOperator
-
Creates a new instance.
- SparkIESelfJoinOperator<Type0 extends Comparable<Type0>,
Type1 extends Comparable<Type1>, Input extends Copyable<Input>> - Class in org.apache.wayang.iejoin.operators -
Spark implementation of the
IESelfJoinOperator
. - SparkIESelfJoinOperator(DataSetType<Input>, TransformationDescriptor<Input, Type0>, IEJoinMasterOperator.JoinCondition, TransformationDescriptor<Input, Type1>, IEJoinMasterOperator.JoinCondition) - Constructor for class org.apache.wayang.iejoin.operators.SparkIESelfJoinOperator
-
Creates a new instance.
- SparkIntersectOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
JoinOperator
. - SparkIntersectOperator(Class<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkIntersectOperator
- SparkIntersectOperator(IntersectOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkIntersectOperator
-
Copies an instance (exclusive of broadcasts).
- SparkIntersectOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkIntersectOperator
- SparkJoinOperator<InputType0,
InputType1, KeyType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
JoinOperator
. - SparkJoinOperator(JoinOperator<InputType0, InputType1, KeyType>) - Constructor for class org.apache.wayang.spark.operators.SparkJoinOperator
-
Copies an instance (exclusive of broadcasts).
- SparkJoinOperator(DataSetType<InputType0>, DataSetType<InputType1>, TransformationDescriptor<InputType0, KeyType>, TransformationDescriptor<InputType1, KeyType>) - Constructor for class org.apache.wayang.spark.operators.SparkJoinOperator
-
Creates a new instance.
- SparkKafkaTopicSink<T> - Class in org.apache.wayang.spark.operators
-
Implementation of the
KafkaTopicSink
operator for the Spark platform. - SparkKafkaTopicSink() - Constructor for class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- SparkKafkaTopicSink(String, TransformationDescriptor<T, String>) - Constructor for class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- SparkKafkaTopicSink(KafkaTopicSink<T>) - Constructor for class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- SparkKafkaTopicSource - Class in org.apache.wayang.spark.operators
-
Provides a
Collection
to a Spark job. - SparkKafkaTopicSource(String) - Constructor for class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- SparkKafkaTopicSource(String, String) - Constructor for class org.apache.wayang.spark.operators.SparkKafkaTopicSource
- SparkKafkaTopicSource(KafkaTopicSource) - Constructor for class org.apache.wayang.spark.operators.SparkKafkaTopicSource
-
Copies an instance (exclusive of broadcasts).
- SparkKMeansOperator - Class in org.apache.wayang.spark.operators.ml
- SparkKMeansOperator(int) - Constructor for class org.apache.wayang.spark.operators.ml.SparkKMeansOperator
- SparkKMeansOperator(KMeansOperator) - Constructor for class org.apache.wayang.spark.operators.ml.SparkKMeansOperator
- SparkKMeansOperator.Model - Class in org.apache.wayang.spark.operators.ml
- SparkLinearRegressionOperator - Class in org.apache.wayang.spark.operators.ml
- SparkLinearRegressionOperator(boolean) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator
- SparkLinearRegressionOperator(LinearRegressionOperator) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator
- SparkLinearRegressionOperator.Model - Class in org.apache.wayang.spark.operators.ml
- SparkLinearSVCOperator - Class in org.apache.wayang.spark.operators.ml
- SparkLinearSVCOperator(int, double) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator
- SparkLinearSVCOperator(LinearSVCOperator) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator
- SparkLinearSVCOperator.Model - Class in org.apache.wayang.spark.operators.ml
- SparkListener - Class in org.apache.wayang.spark.monitoring.metrics
-
A Spark listener implementation that captures events generated during the Spark job execution and sends them to a Kafka topic for further processing.
- SparkListener() - Constructor for class org.apache.wayang.spark.monitoring.metrics.SparkListener
-
Default constructor that initializes the Kafka producer and various data lists.
- SparkLocalCallbackSink<T extends Serializable> - Class in org.apache.wayang.spark.operators
-
Implementation of the
LocalCallbackSink
operator for the Spark platform. - SparkLocalCallbackSink(Consumer<T>, DataSetType) - Constructor for class org.apache.wayang.spark.operators.SparkLocalCallbackSink
-
Creates a new instance.
- SparkLocalCallbackSink(LocalCallbackSink<T>) - Constructor for class org.apache.wayang.spark.operators.SparkLocalCallbackSink
-
Copies an instance (exclusive of broadcasts).
- SparkLogisticRegressionOperator - Class in org.apache.wayang.spark.operators.ml
- SparkLogisticRegressionOperator(boolean) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator
- SparkLogisticRegressionOperator(LogisticRegressionOperator) - Constructor for class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator
- SparkLogisticRegressionOperator.Model - Class in org.apache.wayang.spark.operators.ml
- SparkLoopOperator<InputType,
ConvergenceType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
LoopOperator
. - SparkLoopOperator(LoopOperator<InputType, ConvergenceType>) - Constructor for class org.apache.wayang.spark.operators.SparkLoopOperator
-
Creates a copy of the given
LoopOperator
. - SparkLoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, FunctionDescriptor.SerializablePredicate<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.spark.operators.SparkLoopOperator
-
Creates a new instance.
- SparkLoopOperator(DataSetType<InputType>, DataSetType<ConvergenceType>, PredicateDescriptor<Collection<ConvergenceType>>, Integer) - Constructor for class org.apache.wayang.spark.operators.SparkLoopOperator
- SparkMapOperator<InputType,
OutputType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
MapOperator
. - SparkMapOperator(MapOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.spark.operators.SparkMapOperator
-
Copies an instance (exclusive of broadcasts).
- SparkMapOperator(DataSetType, DataSetType, TransformationDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.spark.operators.SparkMapOperator
-
Creates a new instance.
- SparkMapPartitionsOperator<InputType,
OutputType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
MapPartitionsOperator
. - SparkMapPartitionsOperator(MapPartitionsOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
-
Copies an instance (exclusive of broadcasts).
- SparkMapPartitionsOperator(MapPartitionsDescriptor<InputType, OutputType>) - Constructor for class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
-
Creates a new instance.
- SparkMapPartitionsOperator(MapPartitionsDescriptor<InputType, OutputType>, DataSetType<InputType>, DataSetType<OutputType>) - Constructor for class org.apache.wayang.spark.operators.SparkMapPartitionsOperator
-
Creates a new instance.
- sparkMappings - Static variable in class org.apache.wayang.iejoin.mapping.Mappings
-
Mapping
s towards theSparkPlatform
. - SparkMaterializedGroupByOperator<Type,
KeyType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
MaterializedGroupByOperator
. - SparkMaterializedGroupByOperator(MaterializedGroupByOperator<Type, KeyType>) - Constructor for class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
-
Copies an instance (exclusive of broadcasts).
- SparkMaterializedGroupByOperator(TransformationDescriptor<Type, KeyType>, DataSetType<Type>, DataSetType<Iterable<Type>>) - Constructor for class org.apache.wayang.spark.operators.SparkMaterializedGroupByOperator
- SparkMLModel<X,
Y> - Interface in org.apache.wayang.spark.model - SparkMLPlugin - Class in org.apache.wayang.spark.plugin
- SparkMLPlugin() - Constructor for class org.apache.wayang.spark.plugin.SparkMLPlugin
- SparkModelTransformOperator<X,
Y> - Class in org.apache.wayang.spark.operators.ml -
Deprecated.
- SparkModelTransformOperator(ModelTransformOperator<X, Y>) - Constructor for class org.apache.wayang.spark.operators.ml.SparkModelTransformOperator
-
Deprecated.
- SparkModelTransformOperator(DataSetType<X>, DataSetType<Tuple2<X, Y>>) - Constructor for class org.apache.wayang.spark.operators.ml.SparkModelTransformOperator
-
Deprecated.
- SparkObjectFileSink<T> - Class in org.apache.wayang.spark.operators
-
Operator
for theSparkPlatform
that creates a sequence file. - SparkObjectFileSink(String, DataSetType<T>) - Constructor for class org.apache.wayang.spark.operators.SparkObjectFileSink
- SparkObjectFileSink(ObjectFileSink<T>) - Constructor for class org.apache.wayang.spark.operators.SparkObjectFileSink
- SparkObjectFileSink(DataSetType<T>) - Constructor for class org.apache.wayang.spark.operators.SparkObjectFileSink
- SparkObjectFileSource<T> - Class in org.apache.wayang.spark.operators
-
Operator
for theSparkPlatform
that creates a sequence file. - SparkObjectFileSource(String, DataSetType<T>) - Constructor for class org.apache.wayang.spark.operators.SparkObjectFileSource
- SparkObjectFileSource(ObjectFileSource) - Constructor for class org.apache.wayang.spark.operators.SparkObjectFileSource
- SparkObjectFileSource(DataSetType<T>) - Constructor for class org.apache.wayang.spark.operators.SparkObjectFileSource
- SparkOperatorProfiler - Class in org.apache.wayang.profiler.spark
-
Allows to instrument an
SparkExecutionOperator
. - SparkOperatorProfiler(Supplier<SparkExecutionOperator>, Configuration, Supplier<?>...) - Constructor for class org.apache.wayang.profiler.spark.SparkOperatorProfiler
- SparkOperatorProfiler.Result - Class in org.apache.wayang.profiler.spark
-
The result of a single profiling run.
- SparkParquetSource - Class in org.apache.wayang.spark.operators
-
Provides a
Collection
to a Spark job. - SparkParquetSource(String, String[]) - Constructor for class org.apache.wayang.spark.operators.SparkParquetSource
- SparkParquetSource(ParquetSource) - Constructor for class org.apache.wayang.spark.operators.SparkParquetSource
-
Copies an instance (exclusive of broadcasts).
- SparkPlatform - Class in org.apache.wayang.spark.platform
-
Platform
for Apache Spark. - sparkPlugin() - Static method in class org.apache.wayang.iejoin.IEJoin
- SparkPredictOperator<X,
Y> - Class in org.apache.wayang.spark.operators.ml - SparkPredictOperator(PredictOperator<X, Y>) - Constructor for class org.apache.wayang.spark.operators.ml.SparkPredictOperator
- SparkPredictOperator(DataSetType<X>, DataSetType<Y>) - Constructor for class org.apache.wayang.spark.operators.ml.SparkPredictOperator
- SparkRandomPartitionSampleOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
SampleOperator
. - SparkRandomPartitionSampleOperator(SampleOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
-
Copies an instance (exclusive of broadcasts).
- SparkRandomPartitionSampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, FunctionDescriptor.SerializableLongUnaryOperator) - Constructor for class org.apache.wayang.spark.operators.SparkRandomPartitionSampleOperator
-
Creates a new instance.
- SparkReduceByOperator<Type,
KeyType> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
ReduceByOperator
. - SparkReduceByOperator(ReduceByOperator<Type, KeyType>) - Constructor for class org.apache.wayang.spark.operators.SparkReduceByOperator
-
Copies an instance (exclusive of broadcasts).
- SparkReduceByOperator(DataSetType<Type>, TransformationDescriptor<Type, KeyType>, ReduceDescriptor<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkReduceByOperator
-
Creates a new instance.
- SparkRepeatOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
RepeatOperator
. - SparkRepeatOperator(int, DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkRepeatOperator
- SparkRepeatOperator(RepeatOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkRepeatOperator
- SparkShufflePartitionSampleOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
SparkShufflePartitionSampleOperator
. - SparkShufflePartitionSampleOperator(SampleOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
-
Copies an instance (exclusive of broadcasts).
- SparkShufflePartitionSampleOperator(FunctionDescriptor.SerializableIntUnaryOperator, DataSetType<Type>, FunctionDescriptor.SerializableLongUnaryOperator) - Constructor for class org.apache.wayang.spark.operators.SparkShufflePartitionSampleOperator
-
Creates a new instance.
- SparkSortOperator<Type,
Key> - Class in org.apache.wayang.spark.operators -
Spark implementation of the
SortOperator
. - SparkSortOperator(SortOperator<Type, Key>) - Constructor for class org.apache.wayang.spark.operators.SparkSortOperator
-
Copies an instance (exclusive of broadcasts).
- SparkSortOperator(TransformationDescriptor<Type, Key>, DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkSortOperator
-
Creates a new instance.
- SparkSourceProfiler - Class in org.apache.wayang.profiler.spark
-
SparkOperatorProfiler
implementation forSparkExecutionOperator
s with one input and one output. - SparkSourceProfiler(Supplier<SparkExecutionOperator>, Configuration, Supplier<?>) - Constructor for class org.apache.wayang.profiler.spark.SparkSourceProfiler
- SparkTextFileSink<T> - Class in org.apache.wayang.spark.operators
-
Implementation of the
TextFileSink
operator for the Spark platform. - SparkTextFileSink(String, TransformationDescriptor<T, String>) - Constructor for class org.apache.wayang.spark.operators.SparkTextFileSink
- SparkTextFileSink(TextFileSink<T>) - Constructor for class org.apache.wayang.spark.operators.SparkTextFileSink
- SparkTextFileSource - Class in org.apache.wayang.spark.operators
-
Provides a
Collection
to a Spark job. - SparkTextFileSource(String) - Constructor for class org.apache.wayang.spark.operators.SparkTextFileSource
- SparkTextFileSource(String, String) - Constructor for class org.apache.wayang.spark.operators.SparkTextFileSource
- SparkTextFileSource(TextFileSource) - Constructor for class org.apache.wayang.spark.operators.SparkTextFileSource
-
Copies an instance (exclusive of broadcasts).
- SparkTextFileSourceProfiler - Class in org.apache.wayang.profiler.spark
-
SparkOperatorProfiler
for theSparkTextFileSource
. - SparkTextFileSourceProfiler(Configuration, Supplier<?>) - Constructor for class org.apache.wayang.profiler.spark.SparkTextFileSourceProfiler
- SparkTsvFileSink<T extends Tuple2<?,
?>> - Class in org.apache.wayang.spark.operators -
Operator
for theSparkPlatform
that creates a TSV file. - SparkTsvFileSink(String, DataSetType<T>) - Constructor for class org.apache.wayang.spark.operators.SparkTsvFileSink
- SparkTsvFileSink(DataSetType<T>) - Constructor for class org.apache.wayang.spark.operators.SparkTsvFileSink
- SparkTsvFileSource<T> - Class in org.apache.wayang.spark.operators
-
Operator
for theSparkPlatform
that creates a sequence file. - SparkTsvFileSource(String, DataSetType<T>) - Constructor for class org.apache.wayang.spark.operators.SparkTsvFileSource
- SparkTsvFileSource(DataSetType) - Constructor for class org.apache.wayang.spark.operators.SparkTsvFileSource
- SparkUnaryOperatorProfiler - Class in org.apache.wayang.profiler.spark
-
SparkOperatorProfiler
implementation forSparkExecutionOperator
s with one input and one output. - SparkUnaryOperatorProfiler(Supplier<SparkExecutionOperator>, Configuration, Supplier<?>) - Constructor for class org.apache.wayang.profiler.spark.SparkUnaryOperatorProfiler
- SparkUnionAllOperator<Type> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
UnionAllOperator
. - SparkUnionAllOperator(UnionAllOperator<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkUnionAllOperator
-
Copies an instance (exclusive of broadcasts).
- SparkUnionAllOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.spark.operators.SparkUnionAllOperator
-
Creates a new instance.
- SparkZipWithIdOperator<InputType> - Class in org.apache.wayang.spark.operators
-
Spark implementation of the
MapOperator
. - SparkZipWithIdOperator(Class<InputType>) - Constructor for class org.apache.wayang.spark.operators.SparkZipWithIdOperator
-
Creates a new instance.
- SparkZipWithIdOperator(ZipWithIdOperator<InputType>) - Constructor for class org.apache.wayang.spark.operators.SparkZipWithIdOperator
-
Copies an instance (exclusive of broadcasts).
- SparkZipWithIdOperator(DataSetType<InputType>) - Constructor for class org.apache.wayang.spark.operators.SparkZipWithIdOperator
-
Creates a new instance.
- SparseVector - Class in org.apache.wayang.ml4all.utils
- SparseVector() - Constructor for class org.apache.wayang.ml4all.utils.SparseVector
- SparseVector(double, int[], double[]) - Constructor for class org.apache.wayang.ml4all.utils.SparseVector
- SparseVector(int[], double[]) - Constructor for class org.apache.wayang.ml4all.utils.SparseVector
- specify(Class<? super T>) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Casts the given
Class
to a more specific one. - specify(Context) - Method in interface org.apache.wayang.core.util.mathex.Expression
-
Turn this dynamic instance into a more static one by directly incorporating the given
Context
. - specify(Context) - Method in class org.apache.wayang.core.util.mathex.model.BinaryOperation
- specify(Context) - Method in class org.apache.wayang.core.util.mathex.model.CompiledFunction
- specify(Context) - Method in class org.apache.wayang.core.util.mathex.model.Constant
- specify(Context) - Method in class org.apache.wayang.core.util.mathex.model.NamedFunction
- SPECULATIVE - Enum constant in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
- split(int) - Method in class org.apache.wayang.flink.operators.CollectionSplittableIterator
- split(String, char) - Static method in class org.apache.wayang.ml4all.utils.StringUtil
-
Split a string with an unknown number of tokens with a given separator.
- split(String, char, int) - Static method in class org.apache.wayang.ml4all.utils.StringUtil
- spliterator() - Method in class org.apache.wayang.core.util.Bitmask
- SQL_TO_STREAM_CONVERSION - Static variable in class org.apache.wayang.genericjdbc.channels.GenericChannelConversions
- SQL_TO_STREAM_CONVERSION - Static variable in class org.apache.wayang.postgres.channels.ChannelConversions
- SQL_TO_STREAM_CONVERSION - Static variable in class org.apache.wayang.sqlite3.channels.ChannelConversions
- SQL_TO_UNCACHED_RDD_CONVERSION - Static variable in class org.apache.wayang.postgres.channels.ChannelConversions
- SQL_TO_UNCACHED_RDD_CONVERSION - Static variable in class org.apache.wayang.sqlite3.channels.ChannelConversions
- SqlContext - Class in org.apache.wayang.api.sql.context
- SqlContext() - Constructor for class org.apache.wayang.api.sql.context.SqlContext
- SqlContext(Configuration) - Constructor for class org.apache.wayang.api.sql.context.SqlContext
- SqlContext(Configuration, List<Plugin>) - Constructor for class org.apache.wayang.api.sql.context.SqlContext
- Sqlite3 - Class in org.apache.wayang.sqlite3
-
Register for relevant components of this module.
- Sqlite3() - Constructor for class org.apache.wayang.sqlite3.Sqlite3
- Sqlite3ConversionPlugin - Class in org.apache.wayang.sqlite3.plugin
- Sqlite3ConversionPlugin() - Constructor for class org.apache.wayang.sqlite3.plugin.Sqlite3ConversionPlugin
- Sqlite3FilterOperator - Class in org.apache.wayang.sqlite3.operators
-
Implementation of the
FilterOperator
for theSqlite3Platform
. - Sqlite3FilterOperator(FilterOperator<Record>) - Constructor for class org.apache.wayang.sqlite3.operators.Sqlite3FilterOperator
- Sqlite3FilterOperator(PredicateDescriptor<Record>) - Constructor for class org.apache.wayang.sqlite3.operators.Sqlite3FilterOperator
- Sqlite3Platform - Class in org.apache.wayang.sqlite3.platform
-
Platform
implementation for SQLite3. - Sqlite3Platform() - Constructor for class org.apache.wayang.sqlite3.platform.Sqlite3Platform
- Sqlite3Plugin - Class in org.apache.wayang.sqlite3.plugin
- Sqlite3Plugin() - Constructor for class org.apache.wayang.sqlite3.plugin.Sqlite3Plugin
- Sqlite3ProjectionOperator - Class in org.apache.wayang.sqlite3.operators
-
Implementation of the
JdbcProjectionOperator
for theSqlite3Platform
. - Sqlite3ProjectionOperator(Class<Record>, Class<Record>, String...) - Constructor for class org.apache.wayang.sqlite3.operators.Sqlite3ProjectionOperator
- Sqlite3ProjectionOperator(ProjectionDescriptor<Record, Record>) - Constructor for class org.apache.wayang.sqlite3.operators.Sqlite3ProjectionOperator
- Sqlite3ProjectionOperator(MapOperator<Record, Record>) - Constructor for class org.apache.wayang.sqlite3.operators.Sqlite3ProjectionOperator
- Sqlite3TableSource - Class in org.apache.wayang.sqlite3.operators
-
Implementation of the
TableSource
for theSqlite3Platform
. - Sqlite3TableSource(String, String...) - Constructor for class org.apache.wayang.sqlite3.operators.Sqlite3TableSource
-
Creates a new instance.
- Sqlite3TableSource(Sqlite3TableSource) - Constructor for class org.apache.wayang.sqlite3.operators.Sqlite3TableSource
- SqlQueryChannel - Class in org.apache.wayang.jdbc.channels
-
Implementation of a
Channel
that is given by a SQL query. - SqlQueryChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.jdbc.channels.SqlQueryChannel
- SqlQueryChannel.Descriptor - Class in org.apache.wayang.jdbc.channels
-
Describes a specific class of
SqlQueryChannel
s belonging to a certainJdbcPlatformTemplate
. - SqlQueryChannel.Instance - Class in org.apache.wayang.jdbc.channels
-
ChannelInstance
implementation forSqlQueryChannel
s. - SqlToRddOperator - Class in org.apache.wayang.jdbc.operators
- SqlToRddOperator(SqlToRddOperator) - Constructor for class org.apache.wayang.jdbc.operators.SqlToRddOperator
- SqlToRddOperator(JdbcPlatformTemplate) - Constructor for class org.apache.wayang.jdbc.operators.SqlToRddOperator
- SqlToRddOperator(JdbcPlatformTemplate, DataSetType<Record>) - Constructor for class org.apache.wayang.jdbc.operators.SqlToRddOperator
- SqlToStreamOperator - Class in org.apache.wayang.jdbc.operators
- SqlToStreamOperator(SqlToStreamOperator) - Constructor for class org.apache.wayang.jdbc.operators.SqlToStreamOperator
- SqlToStreamOperator(JdbcPlatformTemplate) - Constructor for class org.apache.wayang.jdbc.operators.SqlToStreamOperator
-
Creates a new instance.
- SqlToStreamOperator(JdbcPlatformTemplate, DataSetType<Record>) - Constructor for class org.apache.wayang.jdbc.operators.SqlToStreamOperator
-
Creates a new instance.
- SqlToStreamOperator.ResultSetIterator - Class in org.apache.wayang.jdbc.operators
- ss - Variable in class org.apache.wayang.spark.execution.SparkExecutor
-
The
SparkSession
to be used by this instance. - Stage - Interface in org.apache.wayang.spark.monitoring.interfaces
-
This interface represents a stage in a data processing pipeline.
- StageAssignmentTraversal - Class in org.apache.wayang.core.optimizer.enumeration
-
Builds an
ExecutionPlan
from aExecutionTaskFlow
. - StageAssignmentTraversal.StageSplittingCriterion - Interface in org.apache.wayang.core.optimizer.enumeration
-
Criterion to futher split
StageAssignmentTraversal.InterimStage
besides precedence. - stageAttempt(int) - Method in interface org.apache.wayang.spark.monitoring.interfaces.Executor
-
Sets the attempt ID of the stage.
- stageAttempt(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorAdded
- stageAttempt(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorRemoved
- stageAttempt(int) - Method in class org.apache.wayang.spark.monitoring.metrics.ExecutorUpdated
- StageCompleted - Class in org.apache.wayang.spark.monitoring.metrics
-
Represents a completed stage in a distributed computing system.
- StageCompleted() - Constructor for class org.apache.wayang.spark.monitoring.metrics.StageCompleted
- StageExecutorMetrics - Class in org.apache.wayang.spark.monitoring.metrics
-
The StageExecutorMetrics class implements the Stage and SerializableObject interfaces and represents the metrics associated with a stage executed by an executor.
- StageExecutorMetrics() - Constructor for class org.apache.wayang.spark.monitoring.metrics.StageExecutorMetrics
- StageSubmitted - Class in org.apache.wayang.spark.monitoring.metrics
-
The StageSubmitted class implements the Stage and SerializableObject interfaces to represent a submitted stage in a distributed system.
- StageSubmitted() - Constructor for class org.apache.wayang.spark.monitoring.metrics.StageSubmitted
- staging(ML4allModel) - Method in class org.apache.wayang.ml4all.abstraction.api.LocalStage
- staging(ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.KMeansStageWithZeros
- staging(ML4allModel) - Method in class org.apache.wayang.ml4all.algorithms.sgd.SGDStageWithZeros
- STANDARD_OPERATOR_ARGS - Static variable in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- start() - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
-
Start measuring time for this instance.
- start(String...) - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
-
Start a (potentially new) sub-
TimeMeasurement
. - start(String, String...) - Method in class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Starts a
TimeMeasurement
. - startConsuming() - Method in class org.apache.wayang.basic.operators.KafkaTopicSource
- startRecord() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat.BlockBasedOutput
- stealConnections(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Take the input connections away from one operator and give them to another one.
- stealConnections(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
-
Take the output connections away from one operator and give them to another one.
- stealOccupant(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
-
Takes away the occupant
OutputSlot
of thevictim
and connects it to this instance. - stealOccupiedSlots(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
-
Takes away the occupied
InputSlot
s of thevictim
and connects it to this instance. - stop() - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
-
Stop a measurement that has been started via
TimeMeasurement.start()
or derivatives. - stop(String...) - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
-
Stop a measurement that has been started via
TimeMeasurement.start(String...)
or related. - stop(String, String...) - Method in class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Stops a
TimeMeasurement
(if it exists). - stopAll() - Method in class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Stops all
TimeMeasurement
s known to this instance. - StopWatch - Class in org.apache.wayang.commons.util.profiledb.instrumentation
-
Utility to create
TimeMeasurement
s for anExperiment
. - StopWatch(Experiment) - Constructor for class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Creates a new instance for the given
Experiment
. - Storage - Class in org.apache.wayang.commons.util.profiledb.storage
-
Controls how conducted experiments will be persisted and loaded
- Storage(URI) - Constructor for class org.apache.wayang.commons.util.profiledb.storage.Storage
-
Creates a new instance.
- store(OutputSlot<?>, long, OptimizationContext.OperatorContext, Operator) - Method in class org.apache.wayang.core.profiling.CardinalityRepository
- store(PartialExecution) - Method in class org.apache.wayang.core.profiling.ExecutionLog
-
Stores the given
PartialExecution
in this instance. - storeAll(Iterable<PartialExecution>) - Method in class org.apache.wayang.core.profiling.ExecutionLog
-
Stores the given
PartialExecution
s in this instance. - storeAll(ExecutionState, OptimizationContext) - Method in class org.apache.wayang.core.profiling.CardinalityRepository
-
Store the input and output cardinalities for all those
Operator
s that have a measured output cardinality. - stream - Variable in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
-
The stream to which the data is written;
- stream() - Method in class org.apache.wayang.core.profiling.ExecutionLog
-
Streams the contents of this instance.
- stream() - Method in class org.apache.wayang.core.util.Bitmask
- stream() - Method in class org.apache.wayang.core.util.Optional
- STREAM_TO_COLLECTION - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- STREAM_TO_HDFS_OBJECT_FILE - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- STREAM_TO_HDFS_TSV - Static variable in class org.apache.wayang.java.channels.ChannelConversions
- StreamChannel - Class in org.apache.wayang.java.channels
- StreamChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.java.channels.StreamChannel
- StreamChannel.Instance - Class in org.apache.wayang.java.channels
-
JavaChannelInstance
implementation forStreamChannel
s. - StreamChunker(int, BiConsumer<Object[], Integer>) - Constructor for class org.apache.wayang.java.operators.JavaObjectFileSink.StreamChunker
- streamedCrossProduct(List<? extends Iterable<T>>) - Static method in class org.apache.wayang.core.util.WayangCollections
-
Returns an
Iterable
that iterates the cross product of the giveniterables
. - streamLines(String) - Static method in class org.apache.wayang.core.util.fs.FileUtils
-
Creates a
Stream
of a lines of the file. - stride - Variable in class org.apache.wayang.basic.model.op.nn.Conv
- StringUtil - Class in org.apache.wayang.ml4all.utils
- StringUtil() - Constructor for class org.apache.wayang.ml4all.utils.StringUtil
- Subject - Class in org.apache.wayang.commons.util.profiledb.model
-
The subject of an
Experiment
, e.g., an application or algorithm. - Subject(String, String) - Constructor for class org.apache.wayang.commons.util.profiledb.model.Subject
-
Creates a new instance.
- Subplan - Class in org.apache.wayang.core.plan.wayangplan
-
A subplan encapsulates connected operators as a single operator.
- Subplan(List<InputSlot<?>>, List<OutputSlot<?>>) - Constructor for class org.apache.wayang.core.plan.wayangplan.Subplan
-
Creates a new instance with the given operators.
- SubplanCardinalityPusher - Class in org.apache.wayang.core.optimizer.cardinality
- SubplanMatch - Class in org.apache.wayang.core.mapping
-
A subplan match correlates a
SubplanPattern
with its actually matched . - SubplanMatch(SubplanMatch) - Constructor for class org.apache.wayang.core.mapping.SubplanMatch
-
Copy constructor.
- SubplanMatch(SubplanPattern) - Constructor for class org.apache.wayang.core.mapping.SubplanMatch
- SubplanPattern - Class in org.apache.wayang.core.mapping
-
A subplan pattern describes a class of subplans in a
WayangPlan
. - SUCCESS - Enum constant in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
- SUCCESSFUL - Enum constant in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
- SUM_BASE_PRICE - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- SUM_CHARGE - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- SUM_DISC_PRICE - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- SUM_QTY - Variable in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- SUPPORTED_OPS - Static variable in class org.apache.wayang.api.sql.calcite.converter.WayangFilterVisitor
-
for quick sanity check
- SVMModel - Interface in org.apache.wayang.basic.model
- swap() - Method in class org.apache.wayang.basic.data.Tuple2
- swap() - Method in class org.apache.wayang.basic.data.Tuple5
- SwitchForwardCardinalityEstimator - Class in org.apache.wayang.core.optimizer.cardinality
- SwitchForwardCardinalityEstimator(int...) - Constructor for class org.apache.wayang.core.optimizer.cardinality.SwitchForwardCardinalityEstimator
T
- T__0 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__0 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- T__1 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__1 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- T__2 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__2 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- T__3 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__3 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- T__4 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__4 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- T__5 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__5 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- T__6 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__6 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- T__7 - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- T__7 - Static variable in class org.apache.wayang.core.mathex.MathExParser
- tableName() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
-
Returns the table name, qualified with catalog and schema name if applicable, as a parse tree node (
SqlIdentifier
). - TableSource - Class in org.apache.wayang.basic.operators
-
UnarySource
that provides the tuples from a database table. - TableSource(String, String...) - Constructor for class org.apache.wayang.basic.operators.TableSource
-
Creates a new instance.
- TableSource(String, DataSetType<Record>) - Constructor for class org.apache.wayang.basic.operators.TableSource
- TableSource(TableSource) - Constructor for class org.apache.wayang.basic.operators.TableSource
-
Copies an instance (exclusive of broadcasts).
- Task - Interface in org.apache.wayang.spark.monitoring.interfaces
-
The Task interface represents a task in a distributed computing or data processing system.
- Task.TaskStatusForRunning - Enum Class in org.apache.wayang.spark.monitoring.interfaces
-
The TaskStatusForRunning enum represents the possible statuses of a task while it is running.
- TaskEnd - Class in org.apache.wayang.spark.monitoring.metrics
-
Represents the end status of a task execution.
- TaskEnd() - Constructor for class org.apache.wayang.spark.monitoring.metrics.TaskEnd
- TaskGettingResult - Class in org.apache.wayang.spark.monitoring.metrics
-
Represents the getting results of a task execution.
- TaskGettingResult() - Constructor for class org.apache.wayang.spark.monitoring.metrics.TaskGettingResult
- TaskMetric - Class in org.apache.wayang.spark.monitoring.metrics
-
This class represents the metrics for a task in the Apache Wayang monitoring system.
- TaskMetric - Interface in org.apache.wayang.spark.monitoring.interfaces
-
The TaskMetric interface defines the methods used to set and retrieve performance metrics for a given task.
- TaskMetric() - Constructor for class org.apache.wayang.spark.monitoring.metrics.TaskMetric
- TaskStart - Class in org.apache.wayang.spark.monitoring.metrics
-
Represents the start status of a task execution.
- TaskStart() - Constructor for class org.apache.wayang.spark.monitoring.metrics.TaskStart
- tClass - Variable in class org.apache.wayang.basic.operators.ObjectFileSink
- TEMP_DIR_PROPERTY - Static variable in class org.apache.wayang.basic.plugin.WayangBasic
- TENSOR_TO_COLLECTION - Static variable in class org.apache.wayang.tensorflow.channels.ChannelConversions
- TensorChannel - Class in org.apache.wayang.tensorflow.channels
- TensorChannel(OutputSlot<?>) - Constructor for class org.apache.wayang.tensorflow.channels.TensorChannel
- TensorChannel(ChannelDescriptor, OutputSlot<?>) - Constructor for class org.apache.wayang.tensorflow.channels.TensorChannel
- TensorChannel.Instance - Class in org.apache.wayang.tensorflow.channels
-
ChannelInstance
implementation forTensorChannel
s. - Tensorflow - Class in org.apache.wayang.tensorflow
-
Register for relevant components of this module.
- Tensorflow() - Constructor for class org.apache.wayang.tensorflow.Tensorflow
- TensorflowBatchNorm2D<T extends org.tensorflow.types.family.TNumber> - Class in org.apache.wayang.tensorflow.model.op.nn
- TensorflowBatchNorm2D(Graph, Ops, BatchNorm2D, Class<T>) - Constructor for class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm2D
- TensorflowBatchNorm3D<T extends org.tensorflow.types.family.TNumber> - Class in org.apache.wayang.tensorflow.model.op.nn
- TensorflowBatchNorm3D(Graph, Ops, BatchNorm3D, Class<T>) - Constructor for class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm3D
- TensorflowCollectionSource<Type> - Class in org.apache.wayang.tensorflow.operators
-
Provides a
Collection
to a Tensorflow job. - TensorflowCollectionSource(Collection<Type>, DataSetType<Type>) - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowCollectionSource
- TensorflowCollectionSource(CollectionSource) - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowCollectionSource
- TensorflowCollectionSource(DataSetType<Type>) - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowCollectionSource
- TensorflowCollectOperator<Type> - Class in org.apache.wayang.tensorflow.operators
-
Converts
TensorChannel
into aCollectionChannel
- TensorflowCollectOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowCollectOperator
- TensorflowContextReference - Class in org.apache.wayang.tensorflow.execution
- TensorflowContextReference(CrossPlatformExecutor) - Constructor for class org.apache.wayang.tensorflow.execution.TensorflowContextReference
- TensorflowConv2D<T extends org.tensorflow.types.family.TNumber> - Class in org.apache.wayang.tensorflow.model.op.nn
- TensorflowConv2D(Ops, Conv2D, Class<T>) - Constructor for class org.apache.wayang.tensorflow.model.op.nn.TensorflowConv2D
- TensorflowConv3D<T extends org.tensorflow.types.family.TNumber> - Class in org.apache.wayang.tensorflow.model.op.nn
- TensorflowConv3D(Ops, Conv3D, Class<T>) - Constructor for class org.apache.wayang.tensorflow.model.op.nn.TensorflowConv3D
- TensorflowConversionPlugin - Class in org.apache.wayang.tensorflow.plugin
- TensorflowConversionPlugin() - Constructor for class org.apache.wayang.tensorflow.plugin.TensorflowConversionPlugin
- TensorflowConvLSTM2D<T extends org.tensorflow.types.family.TNumber> - Class in org.apache.wayang.tensorflow.model.op.nn
- TensorflowConvLSTM2D(Ops, ConvLSTM2D, Class<T>) - Constructor for class org.apache.wayang.tensorflow.model.op.nn.TensorflowConvLSTM2D
- TensorflowConvLSTM2D.Cell<T extends org.tensorflow.types.family.TNumber> - Class in org.apache.wayang.tensorflow.model.op.nn
- TensorflowDLTrainingOperator - Class in org.apache.wayang.tensorflow.operators
- TensorflowDLTrainingOperator(DLModel, DLTrainingOperator.Option) - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowDLTrainingOperator
- TensorflowDLTrainingOperator(DLTrainingOperator<NdArray<?>, NdArray<?>>) - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowDLTrainingOperator
- TensorflowExecutionOperator - Interface in org.apache.wayang.tensorflow.operators
-
Execution operator for the
TensorflowPlatform
. - TensorflowExecutor - Class in org.apache.wayang.tensorflow.execution
-
Executor
implementation for theTensorflowPlatform
. - TensorflowExecutor(TensorflowPlatform, Job) - Constructor for class org.apache.wayang.tensorflow.execution.TensorflowExecutor
- TensorflowLinear<T extends org.tensorflow.types.family.TNumber> - Class in org.apache.wayang.tensorflow.model.op.nn
- TensorflowLinear(Ops, Linear, Class<T>) - Constructor for class org.apache.wayang.tensorflow.model.op.nn.TensorflowLinear
- TensorflowModel - Class in org.apache.wayang.tensorflow.model
- TensorflowModel(DLModel, Op, Optimizer, Op) - Constructor for class org.apache.wayang.tensorflow.model.TensorflowModel
- TensorflowPlatform - Class in org.apache.wayang.tensorflow.platform
-
Platform
for Tensorflow - TensorflowPlugin - Class in org.apache.wayang.tensorflow.plugin
- TensorflowPlugin() - Constructor for class org.apache.wayang.tensorflow.plugin.TensorflowPlugin
- TensorflowPredictOperator - Class in org.apache.wayang.tensorflow.operators
- TensorflowPredictOperator() - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowPredictOperator
- TensorflowPredictOperator(PredictOperator<NdArray<?>, NdArray<?>>) - Constructor for class org.apache.wayang.tensorflow.operators.TensorflowPredictOperator
- terminate(Double) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.KMeansConvergeOrMaxIterationsLoop
- terminate(Double) - Method in class org.apache.wayang.ml4all.algorithms.sgd.SGDLoop
- terminate(R) - Method in class org.apache.wayang.ml4all.abstraction.api.Loop
- test(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.FilterPredicateImpl
- test(Record) - Method in class org.apache.wayang.api.sql.calcite.converter.functions.SortFilter
- TextFileSink<T> - Class in org.apache.wayang.basic.operators
-
This
UnarySink
writes all incoming data quanta to a text file. - TextFileSink(String, Class<T>) - Constructor for class org.apache.wayang.basic.operators.TextFileSink
-
Creates a new instance with default formatting.
- TextFileSink(String, FunctionDescriptor.SerializableFunction<T, String>, Class<T>) - Constructor for class org.apache.wayang.basic.operators.TextFileSink
-
Creates a new instance.
- TextFileSink(String, TransformationDescriptor<T, String>) - Constructor for class org.apache.wayang.basic.operators.TextFileSink
-
Creates a new instance.
- TextFileSink(TextFileSink<T>) - Constructor for class org.apache.wayang.basic.operators.TextFileSink
-
Creates a copied instance.
- TextFileSinkMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
TextFileSink
toFlinkTextFileSink
. - TextFileSinkMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
TextFileSink
toJavaTextFileSink
. - TextFileSinkMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
CollectionSource
toSparkCollectionSource
. - TextFileSinkMapping() - Constructor for class org.apache.wayang.flink.mapping.TextFileSinkMapping
- TextFileSinkMapping() - Constructor for class org.apache.wayang.java.mapping.TextFileSinkMapping
- TextFileSinkMapping() - Constructor for class org.apache.wayang.spark.mapping.TextFileSinkMapping
- TextFileSource - Class in org.apache.wayang.basic.operators
-
This source reads a text file and outputs the lines as data units.
- TextFileSource(String) - Constructor for class org.apache.wayang.basic.operators.TextFileSource
- TextFileSource(String, String) - Constructor for class org.apache.wayang.basic.operators.TextFileSource
- TextFileSource(TextFileSource) - Constructor for class org.apache.wayang.basic.operators.TextFileSource
-
Copies an instance (exclusive of broadcasts).
- TextFileSource.CardinalityEstimator - Class in org.apache.wayang.basic.operators
-
Custom
CardinalityEstimator
forFlatMapOperator
s. - TextFileSourceMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
TextFileSource
toFlinkTextFileSource
. - TextFileSourceMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
TextFileSource
toJavaTextFileSource
. - TextFileSourceMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
CollectionSource
toSparkCollectionSource
. - TextFileSourceMapping() - Constructor for class org.apache.wayang.flink.mapping.TextFileSourceMapping
- TextFileSourceMapping() - Constructor for class org.apache.wayang.java.mapping.TextFileSourceMapping
- TextFileSourceMapping() - Constructor for class org.apache.wayang.spark.mapping.TextFileSourceMapping
- textFileUrl - Variable in class org.apache.wayang.basic.operators.ObjectFileSink
- textFileUrl - Variable in class org.apache.wayang.basic.operators.TextFileSink
- thatReplaces() - Method in class org.apache.wayang.core.mapping.PlanTransformation
-
Make this instance replace on matches instead of introducing alternatives.
- THREAD_METADATA - Static variable in class org.apache.wayang.api.sql.calcite.jdbc.JdbcSchema
- timeEstimate - Variable in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
TimeEstimate
for theExecutionOperator
. - TimeEstimate - Class in org.apache.wayang.core.optimizer.costs
-
An estimate of time (in milliseconds) expressed as a
ProbabilisticIntervalEstimate
. - TimeEstimate(long) - Constructor for class org.apache.wayang.core.optimizer.costs.TimeEstimate
- TimeEstimate(long, long, double) - Constructor for class org.apache.wayang.core.optimizer.costs.TimeEstimate
- TimeMeasurement - Class in org.apache.wayang.commons.util.profiledb.model.measurement
-
A
Measurement
that captures a certain amount of time in milliseconds. - TimeMeasurement(String) - Constructor for class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
-
Creates a new instance.
- times(double) - Method in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- times(int) - Method in class org.apache.wayang.core.optimizer.costs.LoadEstimate
-
Multiplies the estimated load.
- timesSequential(int) - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
-
Multiplies the values of this instance and nested instances except for the RAM usage, which will not be altered.
- TimeToCostConverter - Class in org.apache.wayang.core.optimizer.costs
-
This (linear) converter turns
TimeEstimate
s into cost estimates. - TimeToCostConverter(double, double) - Constructor for class org.apache.wayang.core.optimizer.costs.TimeToCostConverter
-
Creates a new instance
- toArray() - Method in class org.apache.wayang.core.util.Canonicalizer
- toArray(BitSet) - Static method in class org.apache.wayang.core.util.WayangArrays
- toArray(Collection<Long>) - Static method in class org.apache.wayang.core.util.WayangArrays
-
Convertes the
values
into along
array. - toArray(T1[]) - Method in class org.apache.wayang.core.util.Canonicalizer
- toBasicDataUnitType() - Method in class org.apache.wayang.core.types.BasicDataUnitType
- toBasicDataUnitType() - Method in class org.apache.wayang.core.types.DataUnitGroupType
- toBasicDataUnitType() - Method in class org.apache.wayang.core.types.DataUnitType
-
Converts this instance into a
BasicDataUnitType
. - toCsvString() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- toCsvString() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- toDouble(Object) - Static method in class org.apache.wayang.core.util.ReflectionUtils
-
Convert the given
Object
to adouble
. - toExtensiveString() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
Creates a
String
representation (not strictly ordered) of this instance. - toExtensiveString(boolean) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
Creates a
String
representation of this instance. - toGMeanString() - Method in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- toIndices(Collection<? extends Slot<?>>) - Static method in class org.apache.wayang.core.plan.wayangplan.Slot
-
Creates an
int[]
of the indices of theslots
. - toIntervalString(boolean) - Method in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- toJson() - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
- toJson() - Method in class org.apache.wayang.core.optimizer.costs.LoadEstimate
- toJson() - Method in class org.apache.wayang.core.optimizer.costs.LoadProfile
- toJson() - Method in class org.apache.wayang.core.util.ExplainTreeNode
- toJson() - Method in interface org.apache.wayang.core.util.JsonSerializable
-
Convert this instance to a
WayangJsonObj
. - toJson() - Method in class org.apache.wayang.genericjdbc.operators.GenericSqlToStreamOperator
- toJson() - Method in class org.apache.wayang.jdbc.operators.SqlToRddOperator
- toJson() - Method in class org.apache.wayang.jdbc.operators.SqlToStreamOperator
- toJson(WayangJsonObj) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
-
Serializes this instance to the given
WayangJsonObj
. - toJsonConfig(Individual) - Method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimator
-
Creates a JSON representation of this instance that can be plugged into a properties file.
- toJsonList() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionPlan
-
TODO: ExecutionPlan.toJsonList add documentation labels:documentation,todo
- toJsonMap() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- tokenNames - Static variable in class org.apache.wayang.core.mathex.MathExLexer
-
Deprecated.Use
MathExLexer.VOCABULARY
instead. - tokenNames - Static variable in class org.apache.wayang.core.mathex.MathExParser
-
Deprecated.Use
MathExParser.VOCABULARY
instead. - toMathEx(Individual) - Method in class org.apache.wayang.profiler.log.DynamicLoadEstimator
-
Creates a MathEx expression reflecting this instance under the configuration specified by an
Individual
. - toModificationRel(RelOptCluster, RelOptTable, Prepare.CatalogReader, RelNode, TableModify.Operation, List<String>, List<RexNode>, boolean) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- toNameString() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- toOperator() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- toOperator() - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
- toOperator() - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- TopDownPlanVisitor<Payload,
Return> - Class in org.apache.wayang.core.plan.wayangplan -
Visitor (as in the Visitor Pattern) for
WayangPlan
s. - TopDownPlanVisitor() - Constructor for class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
- topicName - Variable in class org.apache.wayang.basic.operators.KafkaTopicSink
- TopKPruningStrategy - Class in org.apache.wayang.core.optimizer.enumeration
- TopKPruningStrategy() - Constructor for class org.apache.wayang.core.optimizer.enumeration.TopKPruningStrategy
- toPrettyString() - Method in class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Formats the
TimeMeasurement
s to something easily readable. - toPrettyString(String, String) - Method in class org.apache.wayang.commons.util.profiledb.instrumentation.StopWatch
-
Formats the
TimeMeasurement
s to something easily readable. - toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- toString() - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- toString() - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- toString() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangAggregate
- toString() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangFilter
- toString() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangJoin
- toString() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangProject
- toString() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangSort
- toString() - Method in class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- toString() - Method in class org.apache.wayang.apps.tpch.data.q1.ReturnTuple
- toString() - Method in class org.apache.wayang.basic.channels.FileChannel.Descriptor
- toString() - Method in class org.apache.wayang.basic.channels.FileChannel
- toString() - Method in class org.apache.wayang.basic.data.Record
- toString() - Method in class org.apache.wayang.basic.data.Tuple2
- toString() - Method in class org.apache.wayang.basic.data.Tuple5
- toString() - Method in class org.apache.wayang.basic.types.RecordType
- toString() - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
- toString() - Method in class org.apache.wayang.commons.util.profiledb.model.measurement.TimeMeasurement
- toString() - Method in class org.apache.wayang.commons.util.profiledb.model.Subject
- toString() - Method in class org.apache.wayang.core.api.Configuration
- toString() - Method in class org.apache.wayang.core.api.Job
- toString() - Method in class org.apache.wayang.core.function.AggregationDescriptor
- toString() - Method in class org.apache.wayang.core.function.ConsumerDescriptor
- toString() - Method in class org.apache.wayang.core.function.FlatMapDescriptor
- toString() - Method in class org.apache.wayang.core.function.MapPartitionsDescriptor
- toString() - Method in class org.apache.wayang.core.function.PredicateDescriptor
- toString() - Method in class org.apache.wayang.core.function.ReduceDescriptor
- toString() - Method in class org.apache.wayang.core.function.TransformationDescriptor
- toString() - Method in class org.apache.wayang.core.mapping.OperatorPattern
- toString() - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate
- toString() - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
- toString() - Method in class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- toString() - Method in class org.apache.wayang.core.optimizer.costs.NestableLoadProfileEstimator
- toString() - Method in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- toString() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
- toString() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- toString() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- toString() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanImplementation
- toString() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
- toString() - Method in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
- toString() - Method in class org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate
- toString() - Method in class org.apache.wayang.core.plan.executionplan.Channel
- toString() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStage
- toString() - Method in class org.apache.wayang.core.plan.executionplan.ExecutionTask
- toString() - Method in class org.apache.wayang.core.plan.executionplan.PlatformExecution
- toString() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- toString() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- toString() - Method in class org.apache.wayang.core.plan.wayangplan.OperatorBase
- toString() - Method in class org.apache.wayang.core.plan.wayangplan.Slot
- toString() - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal.Activator
- toString() - Method in class org.apache.wayang.core.platform.AbstractChannelInstance
- toString() - Method in class org.apache.wayang.core.platform.AtomicExecution
- toString() - Method in class org.apache.wayang.core.platform.AtomicExecutionGroup
- toString() - Method in class org.apache.wayang.core.platform.ChannelDescriptor
- toString() - Method in class org.apache.wayang.core.platform.ExecutorTemplate
- toString() - Method in class org.apache.wayang.core.platform.Junction
- toString() - Method in class org.apache.wayang.core.platform.lineage.ChannelLineageNode
- toString() - Method in class org.apache.wayang.core.platform.lineage.ExecutionLineageNode
- toString() - Method in class org.apache.wayang.core.platform.Platform
- toString() - Method in class org.apache.wayang.core.types.BasicDataUnitType
- toString() - Method in class org.apache.wayang.core.types.DataSetType
- toString() - Method in class org.apache.wayang.core.types.DataUnitGroupType
- toString() - Method in class org.apache.wayang.core.util.Bitmask
- toString() - Method in class org.apache.wayang.core.util.Canonicalizer
- toString() - Method in class org.apache.wayang.core.util.json.WayangJsonArray
- toString() - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- toString() - Method in class org.apache.wayang.core.util.mathex.model.BinaryOperation
- toString() - Method in class org.apache.wayang.core.util.mathex.model.CompiledFunction
- toString() - Method in class org.apache.wayang.core.util.mathex.model.Constant
- toString() - Method in class org.apache.wayang.core.util.mathex.model.NamedFunction
- toString() - Method in class org.apache.wayang.core.util.mathex.model.UnaryOperation
- toString() - Method in class org.apache.wayang.core.util.mathex.model.Variable
- toString() - Method in class org.apache.wayang.core.util.Tuple
- toString() - Method in class org.apache.wayang.flink.compiler.criterion.WayangValue
- toString() - Method in class org.apache.wayang.iejoin.data.Data
- toString() - Method in class org.apache.wayang.iejoin.operators.spark_helpers.List2AttributesObjectSkinny
- toString() - Method in class org.apache.wayang.ml4all.abstraction.plan.ML4allModel
- toString() - Method in class org.apache.wayang.ml4all.utils.SparseVector
- toString() - Method in class org.apache.wayang.profiler.java.OperatorProfiler.Result
- toString() - Method in class org.apache.wayang.profiler.log.Variable
- toString() - Method in class org.apache.wayang.profiler.spark.SparkOperatorProfiler.Result
- touch(File) - Static method in class org.apache.wayang.core.util.fs.LocalFileSystem
-
Create an empty file.
- toURL(File) - Static method in class org.apache.wayang.core.util.fs.LocalFileSystem
-
Converts a
File
object to a URL. - TournamentSampler<T> - Class in org.apache.wayang.profiler.log.sampling
-
Sampling strategy that simulates a tournament between elements.
- TournamentSampler() - Constructor for class org.apache.wayang.profiler.log.sampling.TournamentSampler
- TPCHQ1WithJavaNative - Class in org.apache.wayang.apps.tpch
-
Main class for the TPC-H app based on Apache Wayang (incubating).
- TPCHQ1WithJavaNative() - Constructor for class org.apache.wayang.apps.tpch.TPCHQ1WithJavaNative
- traceInput(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- traceInput(InputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Return the
InputSlot
that represents the giveninputSlot
. - traceInput(InputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- traceOutput(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative.Alternative
- traceOutput(OutputSlot<T>) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Enter the encased plan by following an
outputSlot
of the encasingCompositeOperator
. - traceOutput(OutputSlot<T>) - Method in class org.apache.wayang.core.plan.wayangplan.Subplan
- train(XT, YT, int, int) - Method in class org.apache.wayang.tensorflow.model.TensorflowModel
- training(Operand<T>, List<Operand<?>>) - Method in class org.apache.wayang.tensorflow.model.op.nn.TensorflowBatchNorm2D
- transform(String) - Method in class org.apache.wayang.ml4all.algorithms.kmeans.TransformCSV
- transform(String) - Method in class org.apache.wayang.ml4all.algorithms.sgd.LibSVMTransform
- transform(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeClassificationOperator.Model
- transform(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkDecisionTreeRegressionOperator.Model
- transform(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkKMeansOperator.Model
- transform(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearRegressionOperator.Model
- transform(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkLinearSVCOperator.Model
- transform(JavaRDD<double[]>) - Method in class org.apache.wayang.spark.operators.ml.SparkLogisticRegressionOperator.Model
- transform(JavaRDD<X>) - Method in interface org.apache.wayang.spark.model.SparkMLModel
-
Deprecated.
- transform(WayangPlan, int) - Method in class org.apache.wayang.core.mapping.PlanTransformation
-
Apply this transformation exhaustively on the current plan.
- transform(V) - Method in class org.apache.wayang.ml4all.abstraction.api.Transform
-
Parses and transforms an input data unit
- Transform<R,
V> - Class in org.apache.wayang.ml4all.abstraction.api - Transform() - Constructor for class org.apache.wayang.ml4all.abstraction.api.Transform
- TransformationDescriptor<Input,
Output> - Class in org.apache.wayang.core.function -
This descriptor pertains to functions that consume a single data unit and output a single data unit.
- TransformationDescriptor() - Constructor for class org.apache.wayang.core.function.TransformationDescriptor
- TransformationDescriptor(FunctionDescriptor.SerializableFunction<Input, Output>, Class<Input>, Class<Output>) - Constructor for class org.apache.wayang.core.function.TransformationDescriptor
- TransformationDescriptor(FunctionDescriptor.SerializableFunction<Input, Output>, Class<Input>, Class<Output>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.TransformationDescriptor
- TransformationDescriptor(FunctionDescriptor.SerializableFunction<Input, Output>, BasicDataUnitType<Input>, BasicDataUnitType<Output>) - Constructor for class org.apache.wayang.core.function.TransformationDescriptor
- TransformationDescriptor(FunctionDescriptor.SerializableFunction<Input, Output>, BasicDataUnitType<Input>, BasicDataUnitType<Output>, LoadProfileEstimator) - Constructor for class org.apache.wayang.core.function.TransformationDescriptor
- TransformCSV - Class in org.apache.wayang.ml4all.algorithms.kmeans
- TransformCSV() - Constructor for class org.apache.wayang.ml4all.algorithms.kmeans.TransformCSV
- TransformCSV(char) - Constructor for class org.apache.wayang.ml4all.algorithms.kmeans.TransformCSV
- TransformPerPartitionWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - TransformPerPartitionWrapper(Transform) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.TransformPerPartitionWrapper
- TransformWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - TransformWrapper(Transform) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.TransformWrapper
- translate(SubplanMatch, int) - Method in class org.apache.wayang.core.mapping.ReplacementSubplanFactory.OfSingleOperators
- translate(SubplanMatch, int) - Method in class org.apache.wayang.core.mapping.ReplacementSubplanFactory
- Transpose - Class in org.apache.wayang.basic.model.op
- Transpose(int[]) - Constructor for class org.apache.wayang.basic.model.op.Transpose
- Transpose(int[], String) - Constructor for class org.apache.wayang.basic.model.op.Transpose
- Transpose(int[], String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Transpose
- Transpose(int[], Op.DType) - Constructor for class org.apache.wayang.basic.model.op.Transpose
- traverse() - Method in class org.apache.wayang.core.plan.wayangplan.traversal.AbstractTopologicalTraversal
- traverse(Collection<? extends Operator>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Traversing as with
PlanTraversal.traverse(Operator, InputSlot, OutputSlot)
for every operator. - traverse(Stream<? extends Operator>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Traversing as with
PlanTraversal.traverse(Operator, InputSlot, OutputSlot)
for every operator. - traverse(OptimizationContext, Configuration) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimationTraversal
-
Traverse and update
CardinalityEstimate
s. - traverse(Operator) - Method in interface org.apache.wayang.core.plan.wayangplan.PlanTraversal.SimpleCallback
-
Perform some action on a traversed operator.
- traverse(Operator) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Traverse the plan by following any connected operators.
- traverse(Operator, InputSlot<?>, OutputSlot<?>) - Method in interface org.apache.wayang.core.plan.wayangplan.PlanTraversal.Callback
-
Perform some action on a traversed operator.
- traverse(Operator, InputSlot<?>, OutputSlot<?>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Traverses a plan.
- traverse(PlanTraversal.Callback) - Method in interface org.apache.wayang.core.plan.wayangplan.OperatorContainer
-
Traverses the encased subplan.
- traverse(T, LazyExecutionLineageNode.Aggregator<T>) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
- traverse(T, LazyExecutionLineageNode.Aggregator<T>, boolean) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
-
Traverse this instance and all its predecessors unless they are marked as executed.
- traverseAndMark(T, LazyExecutionLineageNode.Aggregator<T>) - Method in class org.apache.wayang.core.platform.lineage.LazyExecutionLineageNode
- traverseFocused(Operator, Collection<OutputSlot<?>>) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
Traverses a plan in a focused manner.
- traversingFlat() - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
If this method is invoked, this instance will not enter
CompositeOperator
s and instead treat them just the same asElementaryOperator
s. - traversingHierarchically() - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
-
If this method is invoked, this instance will not treat
Subplan
s andOperatorAlternative
s as normal traversedOperator
s but will rather enter them and traverse their containedOperator
s. - tryCleanupOnError() - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- tryExecute() - Method in class org.apache.wayang.core.util.OneTimeExecutable
-
Invoke
OneTimeExecutable.doExecute()
unless it has been executed already. - tryProvide(ValueProvider<Value>) - Method in class org.apache.wayang.core.api.configuration.ConstantValueProvider
- tryProvide(ValueProvider<Value>) - Method in class org.apache.wayang.core.api.configuration.FunctionalValueProvider
- tryProvide(ValueProvider<Value>) - Method in class org.apache.wayang.core.api.configuration.ValueProvider
-
Try to provide a value.
- tryToProvide(Key, KeyValueProvider<Key, Value>) - Method in class org.apache.wayang.core.api.configuration.FunctionalKeyValueProvider
- tryToProvide(Key, KeyValueProvider<Key, Value>) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
-
Provide the appropriate value for the
key
. - tryToProvide(Key, KeyValueProvider<Key, Value>) - Method in class org.apache.wayang.core.api.configuration.MapBasedKeyValueProvider
- Tuple<T0,
T1> - Class in org.apache.wayang.core.util -
A helper data structure to manage two values without creating new classes.
- Tuple() - Constructor for class org.apache.wayang.core.util.Tuple
- Tuple(T0, T1) - Constructor for class org.apache.wayang.core.util.Tuple
- Tuple2<T0,
T1> - Class in org.apache.wayang.basic.data -
A type for tuples.
- Tuple2() - Constructor for class org.apache.wayang.basic.data.Tuple2
- Tuple2(T0, T1) - Constructor for class org.apache.wayang.basic.data.Tuple2
- Tuple5<T0,
T1, T2, T3, T4> - Class in org.apache.wayang.basic.data -
A type for tuples.
- Tuple5() - Constructor for class org.apache.wayang.basic.data.Tuple5
- Tuple5(T0, T1, T2, T3, T4) - Constructor for class org.apache.wayang.basic.data.Tuple5
- Type - Annotation Interface in org.apache.wayang.commons.util.profiledb.model
- TypeConverter - Class in org.apache.wayang.core.util
- TypeConverter() - Constructor for class org.apache.wayang.core.util.TypeConverter
- typeInformation - Variable in class org.apache.wayang.flink.compiler.KeySelectorFunction
U
- UnaryOperation - Class in org.apache.wayang.core.util.mathex.model
-
An operation
Expression
. - UnaryOperation(char, Expression) - Constructor for class org.apache.wayang.core.util.mathex.model.UnaryOperation
- UnaryOperationContext(MathExParser.ExpressionContext) - Constructor for class org.apache.wayang.core.mathex.MathExParser.UnaryOperationContext
- UnaryOperatorProfiler - Class in org.apache.wayang.profiler.java
- UnaryOperatorProfiler(Supplier<JavaExecutionOperator>, Supplier<?>) - Constructor for class org.apache.wayang.profiler.java.UnaryOperatorProfiler
- UnarySink<T> - Class in org.apache.wayang.core.plan.wayangplan
-
Abstract base-class for sinks with a single input.
- UnarySink() - Constructor for class org.apache.wayang.core.plan.wayangplan.UnarySink
- UnarySink(UnarySink<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnarySink
-
Copies the given instance.
- UnarySink(DataSetType<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnarySink
-
Creates a new instance that does not support broadcast
InputSlot
s. - UnarySink(DataSetType<T>, boolean) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnarySink
-
Creates a new instance.
- UnarySource<T> - Class in org.apache.wayang.core.plan.wayangplan
-
Abstract base class for sources with a single output.
- UnarySource(UnarySource<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnarySource
-
Copies the given instance.
- UnarySource(DataSetType<T>) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnarySource
-
Creates a new instance that does not support broadcast
InputSlot
s. - UnarySource(DataSetType<T>, boolean) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnarySource
-
Creates a new instance.
- UnaryToUnaryOperator<InputType,
OutputType> - Class in org.apache.wayang.core.plan.wayangplan -
This operator has a single input and a single output.
- UnaryToUnaryOperator(UnaryToUnaryOperator<InputType, OutputType>) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnaryToUnaryOperator
-
Copies the given instance.
- UnaryToUnaryOperator(DataSetType<InputType>, DataSetType<OutputType>, boolean) - Constructor for class org.apache.wayang.core.plan.wayangplan.UnaryToUnaryOperator
-
Creates a new instance.
- UNCACHED_DESCRIPTOR - Static variable in class org.apache.wayang.spark.channels.RddChannel
- UNCACHED_RDD_TO_CACHED_RDD - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- UNCACHED_RDD_TO_COLLECTION - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- UNCACHED_RDD_TO_HDFS_OBJECT_FILE - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- UNCACHED_RDD_TO_HDFS_TSV - Static variable in class org.apache.wayang.spark.channels.ChannelConversions
- unchecked() - Method in class org.apache.wayang.core.function.AggregationDescriptor
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in class org.apache.wayang.core.function.ConsumerDescriptor
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in class org.apache.wayang.core.function.FlatMapDescriptor
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in class org.apache.wayang.core.function.MapPartitionsDescriptor
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in class org.apache.wayang.core.function.PredicateDescriptor
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in class org.apache.wayang.core.function.ReduceDescriptor
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in class org.apache.wayang.core.function.TransformationDescriptor
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in interface org.apache.wayang.core.plan.executionplan.ChannelInitializer
-
Deprecated.not needed anymore
- unchecked() - Method in class org.apache.wayang.core.plan.wayangplan.InputSlot
- unchecked() - Method in class org.apache.wayang.core.plan.wayangplan.OutputSlot
- unchecked() - Method in class org.apache.wayang.core.types.BasicDataUnitType
-
In generic code, we do not have the type parameter values of operators, functions etc.
- unchecked() - Method in class org.apache.wayang.core.types.DataSetType
-
In generic code, we do not have the type parameter values of operators, functions etc.
- uncheckedGroup() - Method in class org.apache.wayang.core.types.DataSetType
-
In generic code, we do not have the type parameter values of operators, functions etc.
- uncheckedSerializer - Static variable in interface org.apache.wayang.core.util.JsonSerializable
-
A
JsonSerializer
implementation to serializeJsonSerializable
s. - uncheckedSerializer() - Static method in interface org.apache.wayang.core.util.JsonSerializable
-
A
JsonSerializer
implementation to serializeJsonSerializable
s. - UnionAllMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
UnionAllOperator
toFlinkUnionAllOperator
. - UnionAllMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
UnionAllOperator
toJavaUnionAllOperator
. - UnionAllMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
UnionAllOperator
toSparkUnionAllOperator
. - UnionAllMapping() - Constructor for class org.apache.wayang.flink.mapping.UnionAllMapping
- UnionAllMapping() - Constructor for class org.apache.wayang.java.mapping.UnionAllMapping
- UnionAllMapping() - Constructor for class org.apache.wayang.spark.mapping.UnionAllMapping
- UnionAllOperator<Type> - Class in org.apache.wayang.basic.operators
-
This
Operator
creates the union (bag semantics) of two . - UnionAllOperator(Class<Type>) - Constructor for class org.apache.wayang.basic.operators.UnionAllOperator
-
Creates a new instance.
- UnionAllOperator(UnionAllOperator<Type>) - Constructor for class org.apache.wayang.basic.operators.UnionAllOperator
-
Copies an instance (exclusive of broadcasts).
- UnionAllOperator(DataSetType<Type>) - Constructor for class org.apache.wayang.basic.operators.UnionAllOperator
-
Creates a new instance.
- unionInPlace(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumeration
-
Unions the
PlanImplementation
s of this andthat
instance. - UNKNOWN_DATASET_SIZE - Static variable in class org.apache.wayang.basic.operators.SampleOperator
-
Special dataset size that represents "unknown".
- unregister(ExecutionResource) - Method in interface org.apache.wayang.core.platform.CompositeExecutionResource
-
Unregister a disposed
ExecutionResource
that was maintained by this instance. - unregister(ExecutionResource) - Method in class org.apache.wayang.core.platform.ExecutorTemplate
- UNSPECIFIED_NUM_SLOTS - Static variable in class org.apache.wayang.core.optimizer.costs.LoadEstimator
- unwrap(Class<C>) - Method in class org.apache.wayang.api.sql.calcite.jdbc.JdbcTable
- update(Channel, Channel, Collection<OptimizationContext>, CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.channels.ChannelConversion
-
Update an already existing
ChannelConversion
. - update(Channel, Channel, Collection<OptimizationContext>, CardinalityEstimate) - Method in class org.apache.wayang.core.optimizer.channels.DefaultChannelConversion
- update(ExecutionTask) - Method in class org.apache.wayang.core.plan.executionplan.ExecutionStageLoop
- Update<R,
V> - Class in org.apache.wayang.ml4all.abstraction.api - Update() - Constructor for class org.apache.wayang.ml4all.abstraction.api.Update
- updateBaseEnumeration(PlanEnumeration) - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- updateConversionOperatorCardinalities(PlanImplementation, OptimizationContext, int) - Method in class org.apache.wayang.core.optimizer.cardinality.CardinalityEstimatorManager
-
Update conversion
Operator
cardinalities. - updateCostEstimate() - Method in class org.apache.wayang.core.optimizer.OptimizationContext.OperatorContext
-
Update the
LoadProfile
andTimeEstimate
of this instance. - updateFitness(ToDoubleFunction<Individual>) - Method in class org.apache.wayang.profiler.log.Individual
-
Update the fitness of this instance.
- updateFitness(List<Individual>) - Method in class org.apache.wayang.profiler.log.GeneticOptimizer
-
Update the fitness of the
Individual
s w.r.t. to this instance and sort them according to their new fitness. - UpdateLocal<R,
V> - Class in org.apache.wayang.ml4all.abstraction.api - UpdateLocal() - Constructor for class org.apache.wayang.ml4all.abstraction.api.UpdateLocal
- UpdateLocalWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - UpdateLocalWrapper(UpdateLocal) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.UpdateLocalWrapper
- updateMaturity(Bitmask) - Method in class org.apache.wayang.profiler.log.Individual
- updateOperatorContexts() - Method in class org.apache.wayang.core.optimizer.AggregateOptimizationContext
-
This instance caches for efficiency reasons the aggregated
OptimizationContext.OperatorContext
s. - updateProgress(HashMap<String, Integer>) - Method in class org.apache.wayang.core.monitor.DisabledMonitor
- updateProgress(HashMap<String, Integer>) - Method in class org.apache.wayang.core.monitor.FileMonitor
- updateProgress(HashMap<String, Integer>) - Method in class org.apache.wayang.core.monitor.HttpMonitor
- updateProgress(HashMap<String, Integer>) - Method in class org.apache.wayang.core.monitor.Monitor
- updateProgress(HashMap<String, Integer>) - Method in class org.apache.wayang.core.monitor.ZeroMQMonitor
- UpdateWrapper<R,
V> - Class in org.apache.wayang.ml4all.abstraction.plan.wrappers - UpdateWrapper(Update) - Constructor for class org.apache.wayang.ml4all.abstraction.plan.wrappers.UpdateWrapper
- upstream() - Static method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- useAbstractConvertersForConversion(RelTraitSet, RelTraitSet) - Method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
- Util - Class in org.apache.wayang.applications
- Util() - Constructor for class org.apache.wayang.applications.Util
V
- validate(SqlNode) - Method in class org.apache.wayang.api.sql.calcite.optimizer.Optimizer
- value - Variable in class org.apache.wayang.core.mathex.MathExParser.ConstantContext
- value() - Element in annotation interface org.apache.wayang.commons.util.profiledb.model.Type
- valueOf(String) - Static method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.basic.model.op.Input.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.basic.model.op.Op.DType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.basic.operators.SampleOperator.Methods
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.core.plan.wayangplan.LoopHeadOperator.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.giraph.Algorithm.PageRankParameters.PageRankEnum
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.iejoin.operators.IEJoinMasterOperator.JoinCondition
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.ml4all.abstraction.plan.Platforms
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
-
Returns the enum constant of this class with the specified name.
- ValueProvider<Value> - Class in org.apache.wayang.core.api.configuration
-
Used by
Configuration
s to provide some value. - ValueProvider(Configuration, ValueProvider<Value>) - Constructor for class org.apache.wayang.core.api.configuration.ValueProvider
- ValueProvider.NotAvailableException - Exception in org.apache.wayang.core.api.configuration
- values() - Static method in enum class org.apache.wayang.api.sql.calcite.convention.WayangConvention
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.basic.model.op.Input.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.basic.model.op.Op.DType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.basic.operators.SampleOperator.Methods
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.core.plan.wayangplan.LoopHeadOperator.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.giraph.Algorithm.PageRankParameters.PageRankEnum
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.iejoin.operators.IEJoinMasterOperator.JoinCondition
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.ml4all.abstraction.plan.Platforms
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.wayang.spark.monitoring.interfaces.Task.TaskStatusForRunning
-
Returns an array containing the constants of this enum class, in the order they are declared.
- Variable - Class in org.apache.wayang.core.util.mathex.model
-
A variable
Expression
- Variable - Class in org.apache.wayang.profiler.log
-
A variable that can be altered by an optimization algorithm.
- Variable(int, String) - Constructor for class org.apache.wayang.profiler.log.Variable
- Variable(String) - Constructor for class org.apache.wayang.core.util.mathex.model.Variable
- VariableContext(MathExParser.ExpressionContext) - Constructor for class org.apache.wayang.core.mathex.MathExParser.VariableContext
- variableName - Variable in class org.apache.wayang.core.mathex.MathExParser.VariableContext
- visit(ActualOperator, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
-
todo
- visit(OperatorAlternative, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
-
todo
- visit(Subplan, OutputSlot<?>, Payload) - Method in class org.apache.wayang.core.plan.wayangplan.TopDownPlanVisitor
- visitBinaryOperation(MathExParser.BinaryOperationContext) - Method in class org.apache.wayang.core.mathex.MathExBaseVisitor
-
Visit a parse tree produced by the
binaryOperation
labeled alternative inMathExParser.expression()
. - visitBinaryOperation(MathExParser.BinaryOperationContext) - Method in interface org.apache.wayang.core.mathex.MathExVisitor
-
Visit a parse tree produced by the
binaryOperation
labeled alternative inMathExParser.expression()
. - visitBinaryOperation(MathExParser.BinaryOperationContext) - Method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
- visitConstant(MathExParser.ConstantContext) - Method in class org.apache.wayang.core.mathex.MathExBaseVisitor
-
Visit a parse tree produced by the
constant
labeled alternative inMathExParser.expression()
. - visitConstant(MathExParser.ConstantContext) - Method in interface org.apache.wayang.core.mathex.MathExVisitor
-
Visit a parse tree produced by the
constant
labeled alternative inMathExParser.expression()
. - visitConstant(MathExParser.ConstantContext) - Method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
- visitedIrrelevantOperators - Variable in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- visitedRelevantOperators - Variable in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- visitErrorNode(ErrorNode) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
- visitFunction(MathExParser.FunctionContext) - Method in class org.apache.wayang.core.mathex.MathExBaseVisitor
-
Visit a parse tree produced by the
function
labeled alternative inMathExParser.expression()
. - visitFunction(MathExParser.FunctionContext) - Method in interface org.apache.wayang.core.mathex.MathExVisitor
-
Visit a parse tree produced by the
function
labeled alternative inMathExParser.expression()
. - visitFunction(MathExParser.FunctionContext) - Method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
- visitParensExpression(MathExParser.ParensExpressionContext) - Method in class org.apache.wayang.core.mathex.MathExBaseVisitor
-
Visit a parse tree produced by the
parensExpression
labeled alternative inMathExParser.expression()
. - visitParensExpression(MathExParser.ParensExpressionContext) - Method in interface org.apache.wayang.core.mathex.MathExVisitor
-
Visit a parse tree produced by the
parensExpression
labeled alternative inMathExParser.expression()
. - visitParensExpression(MathExParser.ParensExpressionContext) - Method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
- visitTerminal(TerminalNode) - Method in class org.apache.wayang.core.mathex.MathExBaseListener
- visitUnaryOperation(MathExParser.UnaryOperationContext) - Method in class org.apache.wayang.core.mathex.MathExBaseVisitor
-
Visit a parse tree produced by the
unaryOperation
labeled alternative inMathExParser.expression()
. - visitUnaryOperation(MathExParser.UnaryOperationContext) - Method in interface org.apache.wayang.core.mathex.MathExVisitor
-
Visit a parse tree produced by the
unaryOperation
labeled alternative inMathExParser.expression()
. - visitUnaryOperation(MathExParser.UnaryOperationContext) - Method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
- visitVariable(MathExParser.VariableContext) - Method in class org.apache.wayang.core.mathex.MathExBaseVisitor
-
Visit a parse tree produced by the
variable
labeled alternative inMathExParser.expression()
. - visitVariable(MathExParser.VariableContext) - Method in interface org.apache.wayang.core.mathex.MathExVisitor
-
Visit a parse tree produced by the
variable
labeled alternative inMathExParser.expression()
. - visitVariable(MathExParser.VariableContext) - Method in class org.apache.wayang.core.util.mathex.ExpressionBuilder
- VOCABULARY - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- VOCABULARY - Static variable in class org.apache.wayang.core.mathex.MathExParser
W
- warmUp(Configuration) - Method in class org.apache.wayang.core.platform.Platform
-
Warm up this instance.
- warmUp(Configuration) - Method in class org.apache.wayang.spark.platform.SparkPlatform
- wasExecuted - Variable in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- wasExecuted - Variable in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- wasExecuted() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.ConcatenationActivator
- wasExecuted() - Method in class org.apache.wayang.core.optimizer.enumeration.PlanEnumerator.EnumerationActivator
- wasProduced() - Method in class org.apache.wayang.core.platform.AbstractChannelInstance
- wasProduced() - Method in interface org.apache.wayang.core.platform.ChannelInstance
-
Tells whether this instance was already produced.
- WAYANG_AGGREGATE_RULE - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangRules
- WAYANG_FILTER_RULE - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangRules
- WAYANG_JOIN_RULE - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangRules
- WAYANG_PROJECT_RULE - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangRules
- WAYANG_SORT_RULE - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangRules
- WAYANG_TABLESCAN_ENUMERABLE_RULE - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangRules
- WAYANG_TABLESCAN_RULE - Static variable in class org.apache.wayang.api.sql.calcite.rules.WayangRules
- WayangAggregate - Class in org.apache.wayang.api.sql.calcite.rel
- WayangAggregate(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.wayang.api.sql.calcite.rel.WayangAggregate
- WayangAggregateVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- WayangAggregator - Class in org.apache.wayang.flink.compiler.criterion
-
Class create a that generate aggregatorWrapper
- WayangAggregator() - Constructor for class org.apache.wayang.flink.compiler.criterion.WayangAggregator
- WayangArrays - Class in org.apache.wayang.core.util
-
Utility for handling arrays.
- WayangBasic - Class in org.apache.wayang.basic.plugin
-
Activator for the basic Wayang package.
- WayangBasic() - Constructor for class org.apache.wayang.basic.plugin.WayangBasic
- WayangBasicGraph - Class in org.apache.wayang.basic.plugin
-
Activator for graph operations being executed with Wayang's basic operators.
- WayangBasicGraph() - Constructor for class org.apache.wayang.basic.plugin.WayangBasicGraph
- WayangBasics - Class in org.apache.wayang.basic
-
Register for plugins in the module.
- WayangBasics() - Constructor for class org.apache.wayang.basic.WayangBasics
- WayangCollections - Class in org.apache.wayang.core.util
-
Utilities to operate
Collection
s. - WayangContext - Class in org.apache.wayang.core.api
-
This is the entry point for users to work with Wayang.
- WayangContext() - Constructor for class org.apache.wayang.core.api.WayangContext
- WayangContext(Configuration) - Constructor for class org.apache.wayang.core.api.WayangContext
- WayangConvention - Enum Class in org.apache.wayang.api.sql.calcite.convention
- WayangConvergenceCriterion<T> - Class in org.apache.wayang.flink.compiler.criterion
-
Class create a that generate aggregatorWrapper
- WayangConvergenceCriterion(FunctionDescriptor.SerializablePredicate<Collection<T>>) - Constructor for class org.apache.wayang.flink.compiler.criterion.WayangConvergenceCriterion
- WayangCrossJoinVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- WayangException - Exception in org.apache.wayang.core.api.exception
-
Exception that declares a problem of Wayang.
- WayangException() - Constructor for exception org.apache.wayang.core.api.exception.WayangException
- WayangException(String) - Constructor for exception org.apache.wayang.core.api.exception.WayangException
- WayangException(String, Throwable) - Constructor for exception org.apache.wayang.core.api.exception.WayangException
- WayangException(String, Throwable, boolean, boolean) - Constructor for exception org.apache.wayang.core.api.exception.WayangException
- WayangException(Throwable) - Constructor for exception org.apache.wayang.core.api.exception.WayangException
- WayangFileOutputFormat<IT> - Class in org.apache.wayang.flink.compiler
-
Wrapper for
FileOutputFormat
- WayangFileOutputFormat() - Constructor for class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- WayangFileOutputFormat(String) - Constructor for class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- WayangFileOutputFormat(Path) - Constructor for class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- WayangFileOutputFormat.BlockBasedOutput - Class in org.apache.wayang.flink.compiler
-
Writes a block info at the end of the blocks.
Current implementation uses only int and not long. - WayangFilter - Class in org.apache.wayang.api.sql.calcite.rel
- WayangFilter(RelOptCluster, RelTraitSet, RelNode, RexNode) - Constructor for class org.apache.wayang.api.sql.calcite.rel.WayangFilter
- WayangFilterCriterion<T> - Class in org.apache.wayang.flink.compiler.criterion
-
Class create a for use inside of the LoopOperators
- WayangFilterCriterion(String) - Constructor for class org.apache.wayang.flink.compiler.criterion.WayangFilterCriterion
- WayangFilterVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- wayangFlink(String, String) - Static method in class org.apache.wayang.apps.grep.Grep
- wayangJava(String, String) - Static method in class org.apache.wayang.apps.grep.Grep
- WayangJoin - Class in org.apache.wayang.api.sql.calcite.rel
- WayangJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, Set<CorrelationId>, JoinRelType) - Constructor for class org.apache.wayang.api.sql.calcite.rel.WayangJoin
- WayangJoinVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- WayangJsonArray - Class in org.apache.wayang.core.util.json
-
JSONArray is the wrapper for the
ArrayNode
to enable the easy access to Json data TODO: the java doc is not done because is missing implementation and it performed some modification on the code - WayangJsonArray() - Constructor for class org.apache.wayang.core.util.json.WayangJsonArray
- WayangJsonObj - Class in org.apache.wayang.core.util.json
-
JSONObject is the wrapper for the
ObjectNode
to enable the easy access to the json data TODO: the java doc is not done because is missing implementation and it performed some modification on the code - WayangJsonObj() - Constructor for class org.apache.wayang.core.util.json.WayangJsonObj
- WayangJsonObj(String) - Constructor for class org.apache.wayang.core.util.json.WayangJsonObj
- WayangJsonObj(Map<String, Object>) - Constructor for class org.apache.wayang.core.util.json.WayangJsonObj
- WayangListValue - Class in org.apache.wayang.flink.compiler.criterion
-
Is a Wrapper for used in the criterion of the Loops
- WayangListValue() - Constructor for class org.apache.wayang.flink.compiler.criterion.WayangListValue
- WayangListValue(Collection) - Constructor for class org.apache.wayang.flink.compiler.criterion.WayangListValue
- WayangMultiConditionJoinVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- WayangPlan - Class in org.apache.wayang.core.plan.wayangplan
-
A Wayang plan consists of a set of
Operator
s. - WayangPlan(Operator...) - Constructor for class org.apache.wayang.core.plan.wayangplan.WayangPlan
-
Creates a new instance and does some preprocessing (such as loop isolation).
- wayangPlatform(String, String, Plugin) - Static method in class org.apache.wayang.apps.grep.Grep
- WayangProgram - Class in org.apache.wayang.api.sql.calcite.optimizer
- WayangProject - Class in org.apache.wayang.api.sql.calcite.rel
- WayangProject(RelOptCluster, RelTraitSet, RelNode, List<? extends RexNode>, RelDataType) - Constructor for class org.apache.wayang.api.sql.calcite.rel.WayangProject
- WayangProjectVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- WayangRel - Interface in org.apache.wayang.api.sql.calcite.rel
- WayangRelConverter - Class in org.apache.wayang.api.sql.calcite.converter
- WayangRelConverter() - Constructor for class org.apache.wayang.api.sql.calcite.converter.WayangRelConverter
- WayangRelConverter(Configuration) - Constructor for class org.apache.wayang.api.sql.calcite.converter.WayangRelConverter
- WayangRules - Class in org.apache.wayang.api.sql.calcite.rules
- WayangSchema - Class in org.apache.wayang.api.sql.calcite.schema
- WayangSchema(String, Map<String, Table>) - Constructor for class org.apache.wayang.api.sql.calcite.schema.WayangSchema
- WayangSchemaBuilder - Class in org.apache.wayang.api.sql.calcite.schema
- WayangSort - Class in org.apache.wayang.api.sql.calcite.rel
- WayangSort(RelOptCluster, RelTraitSet, List<RelHint>, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.wayang.api.sql.calcite.rel.WayangSort
- WayangSortRule - Class in org.apache.wayang.api.sql.calcite.rules
-
Rule that converts
LogicalSort
to Wayang conventionWayangSort
- WayangSortRule(ConverterRule.Config) - Constructor for class org.apache.wayang.api.sql.calcite.rules.WayangSortRule
- WayangSortVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- wayangSpark(String, String) - Static method in class org.apache.wayang.apps.grep.Grep
- WayangTable - Class in org.apache.wayang.api.sql.calcite.schema
- WayangTable(String, List<String>, List<SqlTypeName>, WayangTableStatistic) - Constructor for class org.apache.wayang.api.sql.calcite.schema.WayangTable
- WayangTableBuilder - Class in org.apache.wayang.api.sql.calcite.schema
- WayangTableScan - Class in org.apache.wayang.api.sql.calcite.rel
- WayangTableScan(RelOptCluster, RelTraitSet, List<RelHint>, RelOptTable) - Constructor for class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- WayangTableScan(RelOptCluster, RelTraitSet, List<RelHint>, RelOptTable, int[]) - Constructor for class org.apache.wayang.api.sql.calcite.rel.WayangTableScan
- WayangTableScanVisitor - Class in org.apache.wayang.api.sql.calcite.converter
- WayangTableStatistic - Class in org.apache.wayang.api.sql.calcite.schema
- WayangTableStatistic(long) - Constructor for class org.apache.wayang.api.sql.calcite.schema.WayangTableStatistic
- WayangValue<T> - Class in org.apache.wayang.flink.compiler.criterion
-
Implementation of
Value
of flink for use in Wayang - WayangValue() - Constructor for class org.apache.wayang.flink.compiler.criterion.WayangValue
- WayangValue(T) - Constructor for class org.apache.wayang.flink.compiler.criterion.WayangValue
- WeightsUpdate - Class in org.apache.wayang.ml4all.algorithms.sgd
- WeightsUpdate() - Constructor for class org.apache.wayang.ml4all.algorithms.sgd.WeightsUpdate
- WeightsUpdate(double, double) - Constructor for class org.apache.wayang.ml4all.algorithms.sgd.WeightsUpdate
- with(Op...) - Method in class org.apache.wayang.basic.model.op.Op
- with(Plugin) - Method in class org.apache.wayang.core.api.WayangContext
-
Registers the given
Plugin
with this instance. - withAdditionalTest(Predicate<T>) - Method in class org.apache.wayang.core.mapping.OperatorPattern
- withCallback(PlanTraversal.Callback) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- withCallback(PlanTraversal.SimpleCallback) - Method in class org.apache.wayang.core.plan.wayangplan.PlanTraversal
- withDescription(String) - Method in class org.apache.wayang.commons.util.profiledb.model.Experiment
-
Adds a description for this instance.
- withGsonPreparation(Consumer<GsonBuilder>) - Method in class org.apache.wayang.commons.util.profiledb.ProfileDB
-
Apply any changes necessary to
Gson
so that it can be used for de/serialization of custom objects. - withPlugin(Plugin) - Method in class org.apache.wayang.core.api.WayangContext
-
Registers the given
Plugin
with this instance. - withRowCount(long) - Method in class org.apache.wayang.api.sql.calcite.schema.WayangTableBuilder
- withSiblings() - Method in class org.apache.wayang.core.plan.executionplan.Channel
-
Creates a
Stream
of this instance and its siblings. - withSlf4jWarning(String) - Method in class org.apache.wayang.core.api.configuration.KeyValueProvider
-
Log a warning in SLF4J format when using this instance to provide a value.
- withSlf4jWarning(String) - Method in class org.apache.wayang.core.api.configuration.ValueProvider
- withSqlImplementation(String) - Method in class org.apache.wayang.core.function.PredicateDescriptor
-
This function is not built to last.
- withSqlImplementation(String, String) - Method in class org.apache.wayang.core.function.TransformationDescriptor
-
This function is not built to last.
- WordCount - Class in org.apache.wayang.applications
- WordCount - Class in org.apache.wayang.apps.wordcount
- WordCount() - Constructor for class org.apache.wayang.applications.WordCount
- WordCount() - Constructor for class org.apache.wayang.apps.wordcount.WordCount
- WordCountOnKafkaTopic - Class in org.apache.wayang.applications
- WordCountOnKafkaTopic() - Constructor for class org.apache.wayang.applications.WordCountOnKafkaTopic
- WordCountParquet - Class in org.apache.wayang.apps.wordcount
- WordCountParquet() - Constructor for class org.apache.wayang.apps.wordcount.WordCountParquet
- WordCountWithJavaNativeAPI - Class in org.apache.wayang.apps.wordcount
-
Example Apache Wayang (incubating) App that does a word count -- the Hello World of Map/Reduce-like systems.
- WordCountWithJavaNativeAPI() - Constructor for class org.apache.wayang.apps.wordcount.WordCountWithJavaNativeAPI
- wrap(List<InputSlot<?>>, List<OutputSlot<?>>, OperatorContainer) - Static method in class org.apache.wayang.core.plan.wayangplan.OperatorContainers
- wrap(List<InputSlot<?>>, List<OutputSlot<?>>, OperatorContainer) - Static method in class org.apache.wayang.core.plan.wayangplan.Subplan
-
Creates a new instance with the given operators.
- wrap(LoadEstimator) - Static method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimators
-
Exposes a
LoadEstimator
forExecutionOperator
s as aDynamicLoadEstimator
with the caveat that theExecutionOperator
will not be available in the estimation process. - wrap(LoadProfileEstimator) - Static method in class org.apache.wayang.profiler.log.DynamicLoadProfileEstimators
- wrap(LoopHeadOperator, List<InputSlot<?>>, List<OutputSlot<?>>) - Static method in class org.apache.wayang.core.plan.wayangplan.LoopSubplan
-
Creates a new instance with the given operators.
- wrap(Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
-
Wraps an
Operator
: Creates a new instance that mocks the interface (slots) of the given operator, steals the connections from the given operator, adapts its parent and becomes its new parent. Moreover, the given operator is set up as the first alternative. - wrap(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.OperatorAlternative
- wrap(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.SlotMapping
-
Creates a new instance where the
Slot
s of thewrapper
are mapped to theSlot
s of thewrappee
, thereby matching theirSlot
s by their index (as inOperator.getInput(int)
andOperator.getOutput(int)
). - wrap(Operator, Operator) - Static method in class org.apache.wayang.core.plan.wayangplan.Subplan
-
Wrap the given operators in a new instance (unless its a single operator), thereby redirecting cut off connections through this subplan.
- wrap(Operator, OperatorContainer) - Static method in class org.apache.wayang.core.plan.wayangplan.OperatorContainers
-
Wraps an
Operator
in anOperatorContainer
. - WrappedFlatMapDescriptor<Input,
Output> - Class in org.apache.wayang.api.python.function - WrappedFlatMapDescriptor(ByteString, BasicDataUnitType<Input>, BasicDataUnitType<Output>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.api.python.function.WrappedFlatMapDescriptor
- WrappedMapPartitionsDescriptor<Input,
Output> - Class in org.apache.wayang.api.python.function - WrappedMapPartitionsDescriptor(ByteString, Class<Input>, Class<Output>) - Constructor for class org.apache.wayang.api.python.function.WrappedMapPartitionsDescriptor
- WrappedPredicateDescriptor<Input> - Class in org.apache.wayang.api.python.function
- WrappedPredicateDescriptor(ByteString, BasicDataUnitType<Input>, ProbabilisticDoubleInterval, LoadProfileEstimator) - Constructor for class org.apache.wayang.api.python.function.WrappedPredicateDescriptor
- WrappedPythonFunction<Input,
Output> - Class in org.apache.wayang.api.python.function - WrappedPythonFunction(ByteString) - Constructor for class org.apache.wayang.api.python.function.WrappedPythonFunction
- WrappedReduceDescriptor<Type> - Class in org.apache.wayang.api.python.function
- WrappedReduceDescriptor(ByteString, DataUnitGroupType<Type>, BasicDataUnitType<Type>) - Constructor for class org.apache.wayang.api.python.function.WrappedReduceDescriptor
- WrappedTransformationDescriptor<Input,
Output> - Class in org.apache.wayang.api.python.function - WrappedTransformationDescriptor(ByteString, BasicDataUnitType<Input>, BasicDataUnitType<Output>) - Constructor for class org.apache.wayang.api.python.function.WrappedTransformationDescriptor
- wrapWithIterable(Iterator<T>) - Static method in class org.apache.wayang.core.util.Iterators
- write(byte[]) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat.BlockBasedOutput
- write(byte[], int, int) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat.BlockBasedOutput
- write(int) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat.BlockBasedOutput
- write(Kryo, Output, Product) - Method in class org.apache.wayang.flink.operators.ScalaTupleSerializer
- write(BufferedWriter) - Method in class org.apache.wayang.core.util.json.WayangJsonObj
- write(Object, DataOutputStream) - Method in class org.apache.wayang.api.python.executor.ProcessFeeder
- write(DataOutputView) - Method in class org.apache.wayang.flink.compiler.criterion.WayangValue
- write(ExplainTreeNode, String) - Static method in class org.apache.wayang.core.util.ExplainUtils
- writeBytes(Object, DataOutputStream) - Method in class org.apache.wayang.api.python.executor.ProcessFeeder
- writeIteratorToStream(Iterator<Input>, DataOutputStream) - Method in class org.apache.wayang.api.python.executor.ProcessFeeder
- writeKeyValue(Map.Entry, DataOutputStream) - Method in class org.apache.wayang.api.python.executor.ProcessFeeder
- writeRecord(IT) - Method in class org.apache.wayang.flink.compiler.WayangFileOutputFormat
- writeRecord(T) - Method in class org.apache.wayang.flink.compiler.OutputFormatConsumer
- writeToKafka(JavaRDD<T>, String) - Method in class org.apache.wayang.spark.operators.SparkKafkaTopicSink
- writeUDF(ByteString, DataOutputStream) - Method in class org.apache.wayang.api.python.executor.ProcessFeeder
- writeUTF(String, DataOutputStream) - Method in class org.apache.wayang.api.python.executor.ProcessFeeder
- writeVertex(Vertex<LongWritable, DoubleWritable, FloatWritable>) - Method in class org.apache.wayang.giraph.Algorithm.PageRankAlgorithm.PageRankVertexOutputFormat.PageRankVertexWriter
- WS - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- WS - Static variable in class org.apache.wayang.core.mathex.MathExParser
Z
- zero - Static variable in class org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval
-
Instance that basically represents the value
0d
. - ZERO - Static variable in class org.apache.wayang.core.optimizer.costs.TimeEstimate
- ZeroLike - Class in org.apache.wayang.basic.model.op
- ZeroLike() - Constructor for class org.apache.wayang.basic.model.op.ZeroLike
- ZeroLike(String) - Constructor for class org.apache.wayang.basic.model.op.ZeroLike
- ZeroLike(String, Op.DType) - Constructor for class org.apache.wayang.basic.model.op.ZeroLike
- ZeroLike(Op.DType) - Constructor for class org.apache.wayang.basic.model.op.ZeroLike
- zeroLoad - Static variable in class org.apache.wayang.profiler.log.DynamicLoadEstimator
-
Instance that always estimates a load of
0
. - ZeroMQMonitor - Class in org.apache.wayang.core.monitor
-
TODO: Implement
- ZeroMQMonitor() - Constructor for class org.apache.wayang.core.monitor.ZeroMQMonitor
- ZipWithIdMapping - Class in org.apache.wayang.flink.mapping
-
Mapping from
ZipWithIdOperator
toFlinkZipWithIdOperator
. - ZipWithIdMapping - Class in org.apache.wayang.java.mapping
-
Mapping from
ZipWithIdMapping
to a subplan. - ZipWithIdMapping - Class in org.apache.wayang.spark.mapping
-
Mapping from
ZipWithIdOperator
toSparkZipWithIdOperator
. - ZipWithIdMapping() - Constructor for class org.apache.wayang.flink.mapping.ZipWithIdMapping
- ZipWithIdMapping() - Constructor for class org.apache.wayang.java.mapping.ZipWithIdMapping
- ZipWithIdMapping() - Constructor for class org.apache.wayang.spark.mapping.ZipWithIdMapping
- ZipWithIdOperator<InputType> - Class in org.apache.wayang.basic.operators
-
This operators attaches a unique ID to each input data quantum.
- ZipWithIdOperator(Class<InputType>) - Constructor for class org.apache.wayang.basic.operators.ZipWithIdOperator
-
Creates a new instance.
- ZipWithIdOperator(ZipWithIdOperator<InputType>) - Constructor for class org.apache.wayang.basic.operators.ZipWithIdOperator
-
Copies an instance (exclusive of broadcasts).
- ZipWithIdOperator(DataSetType<InputType>) - Constructor for class org.apache.wayang.basic.operators.ZipWithIdOperator
-
Creates a new instance.
_
- _ATN - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- _ATN - Static variable in class org.apache.wayang.core.mathex.MathExParser
- _decisionToDFA - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- _decisionToDFA - Static variable in class org.apache.wayang.core.mathex.MathExParser
- _serializedATN - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- _serializedATN - Static variable in class org.apache.wayang.core.mathex.MathExParser
- _sharedContextCache - Static variable in class org.apache.wayang.core.mathex.MathExLexer
- _sharedContextCache - Static variable in class org.apache.wayang.core.mathex.MathExParser
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
WayangPlan(Operator...)
.