All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractAlternativeCardinalityPusher |
|
AbstractChannelInstance |
|
AbstractReferenceCountable |
|
AbstractTopologicalTraversal<ActivatorType extends AbstractTopologicalTraversal.Activator<ActivationType>,ActivationType extends AbstractTopologicalTraversal.Activation<ActivatorType>> |
Encapsulates logic to traverse a WayangPlan in a topological, bottom-up manner.
|
AbstractTopologicalTraversal.AbortException |
Declares that the current traversal should be aborted.
|
AbstractTopologicalTraversal.Activation<TActivator extends AbstractTopologicalTraversal.Activator<? extends AbstractTopologicalTraversal.Activation<TActivator>>> |
|
AbstractTopologicalTraversal.Activator<TActivation extends AbstractTopologicalTraversal.Activation<? extends AbstractTopologicalTraversal.Activator<TActivation>>> |
|
Action |
This interface represents any piece of code that takes no input and produces no output but may fail.
|
Actions |
Utilities to perform actions.
|
ActualOperator |
Operator free of ambiguities.
|
Adam |
|
addUniqueID<Input extends Copyable<Input>> |
Created by khayyzy on 5/28/16.
|
AggregateOptimizationContext |
|
AggregateWrapper<R> |
|
AggregatingCardinalityEstimator |
|
AggregationDescriptor<InputType,OutputType> |
This descriptor pertains to functions that take multiple data units and aggregate them into a single data unit.
|
Application |
This interface represents an application metrics in a Spark cluster.
|
ApplicationEnd |
The ApplicationEnd class represents an application that has ended.
|
ApplicationStart |
The ApplicationStart class implements the Application and SerializableObject interfaces.
|
ArgMax |
|
AssignWrapper<R> |
|
AssignWrapperLocal<V> |
|
AtomicExecution |
An atomic execution describes the smallest work unit considered by Wayang's cost model.
|
AtomicExecution.KeyOrLoadSerializer |
|
AtomicExecutionGroup |
|
AtomicExecutionGroup.Serializer |
|
Attr |
|
BasicDataUnitType<T> |
A basic data unit type is elementary and not constructed from other data unit types.
|
Battle<T> |
Implementation of a battle between to elements.
|
BinaryOperation |
|
BinaryOperatorAdapter<Type> |
Wraps a BinaryOperator as a Function2 .
|
BinaryOperatorProfiler |
|
BinaryOperatorProfiler |
|
BinaryToUnaryOperator<InputType0,InputType1,OutputType> |
This operator has two inputs and a single output.
|
Bitmask |
A mutable bit-mask.
|
BitSetJoin<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input> |
Created by khayyzy on 5/28/16.
|
BitSetJoin<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>> |
Created by khayyzy on 5/28/16.
|
Breakpoint |
|
BroadcastChannel |
Channel that represents a broadcasted value.
|
build2ListObject<TypeXPivot extends java.lang.Comparable<TypeXPivot>,TypeXRef extends java.lang.Comparable<TypeXRef>,Input extends Copyable<Input>> |
Created by khayyzy on 5/28/16.
|
Canonicalizer<T> |
This utility maintains canonical sets of objects.
|
CardinalityBreakpoint |
|
CardinalityEstimate |
|
CardinalityEstimationTraversal |
|
CardinalityEstimator |
|
CardinalityEstimatorManager |
|
CardinalityPusher |
|
CardinalityRepository |
|
CartesianMapping |
|
CartesianMapping |
|
CartesianMapping |
|
CartesianOperator<InputType0,InputType1> |
This operator returns the cartesian product of elements of input datasets.
|
Cast |
|
Channel |
|
ChannelConversion |
|
ChannelConversionGraph |
|
ChannelConversionGraph.CostbasedTreeSelectionStrategy |
Prefers ChannelConversionGraph.Tree s with lower cost.
|
ChannelConversionGraph.RandomTreeSelectionStrategy |
Prefers ChannelConversionGraph.Tree s with lower cost.
|
ChannelConversions |
|
ChannelConversions |
|
ChannelConversions |
|
ChannelConversions |
|
ChannelConversions |
|
ChannelConversions |
|
ChannelConversions |
|
ChannelDescriptor |
Describes a certain Channel type including further parameters.
|
ChannelInitializer |
|
ChannelInstance |
Represents the actual, allocated resource represented by Channel .
|
ChannelLineageNode |
|
CoGroupMapping |
|
CoGroupMapping |
|
CoGroupMapping |
|
CoGroupOperator<InputType0,InputType1,Key> |
This operator groups both inputs by some key and then matches groups with the same key.
|
CollectionChannel |
|
CollectionProvider<Value> |
Provides a Collection of objects.
|
CollectionSource<T> |
This source takes as input a Java Collection .
|
CollectionSourceMapping |
|
CollectionSourceMapping |
|
CollectionSourceMapping |
|
CollectionSourceMapping |
|
CompiledFunction |
Expression implementation that represents a function with a static implementation.
|
CompositeExecutionResource |
|
CompositeOperator |
A composite operator can be decomposed into smaller operators.
|
Compute<R,V> |
Created by zoi on 22/1/15.
|
ComputeLogisticGradient |
|
ComputePerPartitionWrapper<R,V> |
|
ComputeWrapper<R,V> |
|
Configuration |
|
ConjunctiveBreakpoint |
Breakpoint implementation that disrupts execution if all aggregated Breakpoint s request a disruption.
|
Constant |
|
ConstantLoadProfileEstimator |
|
ConstantValueProvider<Value> |
|
ConsumerDescriptor<T> |
Created by bertty on 13-07-17.
|
ConsumerIteratorAdapter<T> |
Utility to expose interfaces that accept a callback as an Iterator .
|
Context |
Provides contextual variables and functions in order to evaluate an Expression .
|
Convertor |
|
Copyable<Self> |
Implementing objects must be able to provide copies of themselves.
|
CostMeasurement |
This measurement captures execution costs w.r.t. to Wayang's cost model.
|
Counter<T> |
This utility helps to count elements.
|
CountMapping |
|
CountMapping |
|
CountMapping |
|
CountOperator<Type> |
This operator returns the count of elements in this stream.
|
CrossEntropyLoss |
|
CrossPlatformExecutor |
|
CrossProductIterable<T> |
Iterates all combinations, i.e., the Cartesian product, of given Iterable s.
|
CsvRowConverter |
Based on Calcite's CSV enumerator.
|
Data<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>> |
Created by khayyzy on 5/28/16.
|
Data.Comparator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>> |
Created by khayyzy on 5/28/16.
|
DatabaseDescriptor |
This class describes a database.
|
DataComparator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input> |
Created by khayyzy on 5/28/16.
|
DataGenerators |
Utility to create common data generators.
|
DataGenerators.Generator<T> |
|
DataSetChannel |
Describes the situation where one DataSet is operated on, producing a further DataSet .
|
DataSetType<T> |
A data set is an abstraction of the Wayang programming model.
|
DataUnitGroupType<T> |
A grouped data unit type describes just the structure of data units within a grouped dataset.
|
DataUnitType<T> |
The type of data types designate the kind of data that are being passed between operators.
|
DecisionTreeClassificationMapping |
|
DecisionTreeClassificationModel |
|
DecisionTreeClassificationOperator |
|
DefaultCardinalityEstimator |
|
DefaultCardinalityPusher |
|
DefaultChannelConversion |
|
DefaultContext |
Default Context implementation that can be configured.
|
DefaultEstimatableCost |
|
DefaultEstimatableCost.Factory |
|
DefaultLoadEstimator |
Implementation of LoadEstimator that uses a single-point cost function.
|
DefaultOptimizationContext |
|
DisabledMonitor |
|
DiskProfiler |
Profiles the reading and writing speed to some directory.
|
DistinctMapping |
|
DistinctMapping |
|
DistinctMapping |
|
DistinctOperator<Type> |
This operator returns the distinct elements in this dataset.
|
DLModel |
|
DLTrainingOperator<X,Y> |
|
DLTrainingOperator.Option |
|
DLTrainingOperatorMapping |
|
DoWhileMapping |
|
DoWhileMapping |
|
DoWhileMapping |
|
DoWhileOperator<InputType,ConvergenceType> |
This operator has three inputs and two outputs.
|
DummyFilter<InputType> |
Create a FilterFunction that remove the elements null
|
DummyMap<InputType,OutputType> |
Class create a MapFunction that genereta only null as convertion
|
DynamicEstimationContext |
|
DynamicLoadEstimator |
|
DynamicLoadEstimator.SinglePointEstimator |
|
DynamicLoadProfileEstimator |
|
DynamicLoadProfileEstimators |
|
DynamicPlugin |
This Plugin can be arbitrarily customized.
|
ElementaryOperator |
|
EnumerationAlternative |
|
EnumerationBranch |
|
Eq |
|
EstimatableCost |
EstimatableCost defines an interface for optimizer cost in terms of
methods to estimate a PlanImplementation's cost.
|
EstimatableCostFactory |
|
EstimationContext |
|
EstimationContextProperty |
|
EvaluationException |
This exception signals a failed Expression evaluation.
|
ExecutionContext |
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 |
|
ExecutionLog |
|
ExecutionOperator |
An execution operator is handled by a certain platform.
|
ExecutionPlan |
Represents an executable, cross-platform data flow.
|
ExecutionPlanMeasurement |
|
ExecutionPlanMeasurement.ChannelNode |
|
ExecutionPlanMeasurement.Link |
|
ExecutionPlanMeasurement.OperatorNode |
|
ExecutionResource |
Represents a resource allocated for execution that needs to be released manually.
|
ExecutionResourceTemplate |
|
ExecutionStage |
Resides within a PlatformExecution and represents the minimum execution unit that is controlled by Wayang.
|
ExecutionStageLoop |
This class models the execution equivalent of LoopSubplan s.
|
ExecutionState |
|
ExecutionTask |
|
ExecutionTaskFlow |
|
ExecutionTaskFlowCompiler |
|
ExecutionTaskFlowCompiler.Activation |
Propagates a Channel to its consumers.
|
Executor |
|
Executor |
The Executor interface represents an executor in a Spark cluster.
|
Executor.Factory |
|
ExecutorAdded |
The ExecutorAdded class represents an executor added event in a distributed computing system.
|
ExecutorRemoved |
An event class representing the removal of an executor.
|
ExecutorTemplate |
|
ExecutorUpdated |
An implementation of the Executor interface that represents an updated executor.
|
Experiment |
|
ExplainTreeNode |
|
ExplainUtils |
|
ExplicitCollectionProvider<Value> |
|
Expression |
A mathematical expression that can be evaluated.
|
ExpressionBuilder |
This utility builds Expression s from an input String .
|
ExtendedBinaryOperatorAdapter<Type> |
|
ExtendedFlatMapFunctionAdapter<InputType,OutputType> |
|
ExtendedFunction |
Used to enrich regular functions with additional life-cycle methods of Operator s.
|
ExtendedFunction<InputType,OutputType> |
|
ExtendedMapFunctionAdapter<InputType,OutputType> |
|
ExtendedMapPartitionsFunctionAdapter<InputType,OutputType> |
Wraps a Function as a FlatMapFunction .
|
ExtendedPredicateAdapater<Type> |
|
extractData<TypeXPivot extends java.lang.Comparable<TypeXPivot>,TypeXRef extends java.lang.Comparable<TypeXRef>,Input> |
Created by khayyzy on 5/28/16.
|
extractData<TypeXPivot extends java.lang.Comparable<TypeXPivot>,TypeXRef extends java.lang.Comparable<TypeXRef>,Input> |
Created by khayyzy on 5/28/16.
|
FallbackCardinalityEstimator |
Assumes with a confidence of 50% that the output cardinality will be somewhere between 1 and the product of
all 10*input estimates.
|
FileChannel |
Represents a Channel that is realized via a file/set of files.
|
FileChannel.Descriptor |
|
FileChannels |
|
FileMonitor |
|
FileStorage |
|
FileSystem |
Abstraction for accessing a file system.
|
FileSystems |
|
FileUtils |
|
FilterMapping |
|
FilterMapping |
|
FilterMapping |
|
FilterMapping |
|
FilterMapping |
|
FilterMapping |
|
FilterOperator<Type> |
This operator returns a new dataset after filtering by applying predicateDescriptor.
|
filterUnwantedBlocks<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>> |
Created by khayyzy on 5/28/16.
|
FixBreakpoint |
|
FixedSizeCardinalityEstimator |
|
FlatMapDescriptor<Input,Output> |
This descriptor pertains to functions that consume a single data unit and output a group of data units.
|
FlatMapFunctionAdapter<InputType,OutputType> |
Wraps a Function as a FlatMapFunction .
|
FlatMapMapping |
|
FlatMapMapping |
|
FlatMapMapping |
|
FlatMapOperator<InputType,OutputType> |
A flatmap operator represents semantics as they are known from frameworks, such as Spark and Flink.
|
Flink |
Register for relevant components of this module.
|
FlinkBasicPlugin |
|
FlinkCartesianOperator<InputType0,InputType1> |
|
FlinkCoGroupFunction<InputType0,InputType1,OutputType> |
Wrapper of CoGroupFunction of Flink for use in Wayang
|
FlinkCoGroupOperator<InputType0,InputType1,TypeKey> |
|
FlinkCollectionSink<Type> |
|
FlinkCollectionSource<Type> |
|
FlinkContextReference |
Wraps and manages a Flink ExecutionEnvironment to avoid steady re-creation.
|
FlinkConversionPlugin |
|
FlinkCountOperator<Type> |
|
FlinkDistinctOperator<Type> |
|
FlinkDoWhileOperator<InputType,ConvergenceType> |
|
FlinkExecutionContext |
|
FlinkExecutionOperator |
Execution operator for the Flink platform.
|
FlinkExecutor |
|
FlinkFilterOperator<Type> |
|
FlinkFlatMapOperator<InputType,OutputType> |
|
FlinkGlobalMaterializedGroupOperator<Type> |
|
FlinkGlobalReduceOperator<Type> |
|
FlinkGraphPlugin |
|
FlinkGroupByOperator<InputType,KeyType> |
|
FlinkIntersectOperator<Type> |
|
FlinkJoinOperator<InputType0,InputType1,KeyType> |
|
FlinkLocalCallbackSink<Type extends java.io.Serializable> |
|
FlinkLoopOperator<InputType,ConvergenceType> |
|
FlinkMapOperator<InputType,OutputType> |
|
FlinkMapPartitionsOperator<InputType,OutputType> |
|
FlinkMaterializedGroupByOperator<Type,KeyType> |
|
FlinkObjectFileSink<Type> |
|
FlinkObjectFileSource<Type> |
|
FlinkPageRankOperator |
|
FlinkPageRankOperator.BuildOutgoingEdgeList |
A reduce function that takes a sequence of edges and builds the adjacency list for the vertex where the edges
originate.
|
FlinkPageRankOperator.Dampener |
The function that applies the page rank dampening formula.
|
FlinkPageRankOperator.EpsilonFilter |
Filter that filters vertices where the rank difference is below a threshold.
|
FlinkPageRankOperator.JoinVertexWithEdgesMatch |
Join function that distributes a fraction of a vertex's rank to all neighbors.
|
FlinkPageRankOperator.RankAssigner |
A map function that assigns an initial rank to all pages.
|
FlinkPlatform |
|
FlinkReduceByOperator<InputType,KeyType> |
|
FlinkRepeatExpandedOperator<Type> |
|
FlinkRepeatOperator<Type> |
|
FlinkSampleOperator<Type> |
|
FlinkSortOperator<InputType,KeyType> |
|
FlinkTextFileSink<Type> |
Implementation of the TextFileSink operator for the Flink platform.
|
FlinkTextFileSource |
Provides a Collection to a Flink job.
|
FlinkTsvFileSink<Type extends Tuple2<?,?>> |
Created by bertty on 31-10-17.
|
FlinkUnionAllOperator<Type> |
|
FlinkZipWithIdOperator<InputType> |
|
Formats |
Formats different general purpose objects.
|
FullInstrumentationStrategy |
Instruments only outbound Channel s.
|
FunctionalCollectionProvider<Value> |
|
FunctionalKeyValueProvider<Key,Value> |
|
FunctionalValueProvider<Value> |
|
FunctionCompiler |
A compiler translates Wayang functions into executable Flink functions.
|
FunctionCompiler |
A compiler translates Wayang functions into executable Java functions.
|
FunctionCompiler |
|
FunctionCompiler |
A compiler translates Wayang functions into executable Java functions.
|
FunctionCompiler.KeyExtractor<T,K> |
Spark function for building pair RDDs.
|
FunctionCompiler.Reducer<Type> |
Spark function for aggregating data quanta.
|
FunctionCompiler.WayangSparkFunction |
Describes functions coming from Wayang, designated for Spark.
|
FunctionDescriptor |
A function operates on single data units or collections of those.
|
FunctionDescriptor.ExtendedSerializableBinaryOperator<Type> |
|
FunctionDescriptor.ExtendedSerializableConsumer<T> |
|
FunctionDescriptor.ExtendedSerializableFunction<Input,Output> |
|
FunctionDescriptor.ExtendedSerializablePredicate<T> |
|
FunctionDescriptor.SerializableBiFunction<Input0,Input1,Output> |
Decorates the default Function with Serializable , which is required by some distributed frameworks.
|
FunctionDescriptor.SerializableBinaryOperator<Type> |
Decorates the default Function with Serializable , which is required by some distributed frameworks.
|
FunctionDescriptor.SerializableConsumer<T> |
Decorates the default Consumer with Serializable , which is required by some distributed frameworks.
|
FunctionDescriptor.SerializableFunction<Input,Output> |
Decorates the default Function with Serializable , which is required by some distributed frameworks.
|
FunctionDescriptor.SerializableIntUnaryOperator |
|
FunctionDescriptor.SerializableLongUnaryOperator |
|
FunctionDescriptor.SerializablePredicate<T> |
|
FunctionDescriptor.SerializableToDoubleBiFunction<T,U> |
|
FunctionDescriptor.SerializableToLongBiFunction<T,U> |
|
FunctionDescriptor.SerializableToLongFunction<T> |
|
GenericChannelConversions |
|
GenericJdbc |
Register for relevant components of this module.
|
GenericJdbcConversionsPlugin |
|
GenericJdbcExecutionOperator |
|
GenericJdbcExecutor |
|
GenericJdbcFilterOperator |
|
GenericJdbcPlatform |
Platform implementation for GenericJdbc.
|
GenericJdbcPlugin |
|
GenericJdbcProjectionOperator |
|
GenericJdbcTableSource |
|
GenericSqlToStreamOperator |
|
GeneticOptimizer |
|
GeneticOptimizerApp |
|
Giraph |
Register for relevant components of this module.
|
GiraphExecutionOperator |
|
GiraphExecutor |
|
GiraphPageRankOperator |
|
GiraphPlatform |
|
GiraphPlugin |
|
GlobalMaterializedGroupMapping |
|
GlobalMaterializedGroupMapping |
|
GlobalMaterializedGroupMapping |
|
GlobalMaterializedGroupOperator<Type> |
This operator groups the elements of a data set into a single data quantum.
|
GlobalReduceMapping |
|
GlobalReduceMapping |
|
GlobalReduceMapping |
|
GlobalReduceMapping |
|
GlobalReduceOperator<Type> |
This operator groups the elements of a data set and aggregates the groups.
|
GradientDescent |
|
Grep |
|
GroupByMapping |
|
GroupByOperator<Input,Key> |
This is the auxiliary GroupBy operator, i.e., it behaves differently depending on its context.
|
GroupKey |
Grouping key used in Query 1.
|
HadoopFileSystem |
|
HttpMonitor |
TODO: Implement
|
IEJoin |
|
IEJoinMapping |
|
IEJoinMapping |
|
IEJoinMasterOperator |
This operator decides the correct sorting orders for IEJoin
|
IEJoinMasterOperator.JoinCondition |
Created by khayyzy on 5/19/16.
|
IEJoinOperator<Type0,Type1,Input> |
This operator applies inequality join on elements of input datasets.
|
IESelfJoinMapping |
|
IESelfJoinMapping |
|
IESelfJoinOperator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input> |
This operator applies inequality self join on elements of input datasets.
|
Individual |
|
Input |
|
Input.Type |
|
InputSlot<T> |
An input slot declares an input of an Operator .
|
InstrumentationStrategy |
|
IntersectMapping |
|
IntersectMapping |
|
IntersectMapping |
|
IntersectOperator<Type> |
This operator returns the set intersection of elements of input datasets.
|
IntervalLoadEstimator |
Implementation of LoadEstimator that uses a interval-based cost function.
|
Iterators |
Utilities for the work with Iterator s.
|
Java |
Register for relevant components of this module.
|
JavaBasicPlugin |
|
JavaCartesianOperator<InputType0,InputType1> |
|
JavaChannelConversionPlugin |
|
JavaChannelInstance |
Defines execution logic to handle a Channel .
|
JavaCoGroupOperator<InputType0,InputType1,KeyType> |
|
JavaCollectionSource<T> |
|
JavaCollectionSourceProfiler |
|
JavaCollectOperator<Type> |
|
JavaCountOperator<Type> |
|
JavaCSVTableSource<T> |
|
JavaDistinctOperator<Type> |
|
JavaDoWhileOperator<InputType,ConvergenceType> |
|
JavaExecutionContext |
|
JavaExecutionOperator |
Execution operator for the Java platform.
|
JavaExecutor |
|
JavaFilterOperator<Type> |
|
JavaFlatMapOperator<InputType,OutputType> |
|
JavaGlobalMaterializedGroupOperator<Type> |
|
JavaGlobalReduceOperator<Type> |
|
JavaGraphPlugin |
|
JavaIEJoinOperator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input> |
|
JavaIESelfJoinOperator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input> |
|
JavaIntersectOperator<Type> |
|
JavaJoinOperator<InputType0,InputType1,KeyType> |
|
JavaKafkaTopicSink<T> |
|
JavaKafkaTopicSource |
|
JavaLocalCallbackSink<T extends java.io.Serializable> |
|
JavaLoopOperator<InputType,ConvergenceType> |
|
JavaMapOperator<InputType,OutputType> |
|
JavaMapPartitionsOperator<InputType,OutputType> |
|
JavaMaterializedGroupByOperator<Type,KeyType> |
|
JavaObjectFileSink<T> |
|
JavaObjectFileSink.StreamChunker |
Utility to chunk a Stream into portions of fixed size.
|
JavaObjectFileSource<T> |
|
JavaPageRankOperator |
|
JavaPlatform |
Platform for a single JVM executor based on the Stream library.
|
JavaRandomSampleOperator<Type> |
|
JavaReduceByOperator<Type,KeyType> |
|
JavaRepeatOperator<Type> |
|
JavaReservoirSampleOperator<Type> |
|
JavaSortOperator<Type,Key> |
|
JavaTextFileSink<T> |
|
JavaTextFileSource |
|
JavaTextFileSourceProfiler |
|
JavaTsvFileSink<T extends Tuple2<?,?>> |
|
JavaTsvFileSource<T> |
|
JavaUnionAllOperator<Type> |
|
JdbcExecutionOperator |
|
JdbcExecutor |
|
JdbcFilterOperator |
|
JdbcJoinOperator<KeyType> |
|
JdbcPlatformTemplate |
Platform implementation for a JDBC-accessible database.
|
JdbcProjectionOperator |
Projects the fields of Record s.
|
JdbcSchema |
Implementation of Schema that is backed by a JDBC data source.
|
JdbcSchema.Factory |
Schema factory that creates a
JdbcSchema .
|
JdbcSchema.Foo |
Do not use.
|
JDBCStorage |
|
JdbcTable |
Queryable that gets its data from a table within a JDBC connection.
|
JdbcTableSource |
|
Job |
Describes a job that is to be executed using Wayang.
|
Job |
The Job interface represents a job to be executed in a distributed system.
|
JobEnd |
JobEnd class represents a job's end in a system.
|
JobStart |
JobStart class represents a job's start in a system.
|
JoinMapping |
|
JoinMapping |
|
JoinMapping |
|
JoinMapping |
|
JoinOperator<InputType0,InputType1,Key> |
This operator returns the cartesian product of elements of input datasets.
|
JsonSerializable |
This interface prescribes implementing instances to be able to provide itself as a WayangJsonObj .
|
JsonSerializable.Serializer<T extends JsonSerializable> |
|
JsonSerializables |
|
JsonSerializer<T> |
|
JuelUtils |
Utilities to deal with JUEL expressions.
|
JuelUtils.JuelFunction<T> |
|
Junction |
|
KafkaTopicSink<T> |
This UnarySink writes all incoming data quanta to a single Kafka topic.
|
KafkaTopicSinkMapping |
|
KafkaTopicSinkMapping |
|
KafkaTopicSource |
This source reads messages from a Kafka topic and outputs the messages as data units.
|
KafkaTopicSourceMapping |
|
KafkaTopicSourceMapping |
|
KeySelectorDistinct<T> |
Wrapper for KeySelector
|
KeySelectorFunction<T,K> |
Wrapper for KeySelector
|
KeyValueProvider<Key,Value> |
|
KeyValueProvider.NoSuchKeyException |
|
KMeansCompute |
|
KMeansConvergeOrMaxIterationsLoop |
|
KMeansMapping |
|
KMeansModel |
|
KMeansOperator |
|
KMeansStageWithZeros |
|
KMeansUpdate |
|
LatentOperatorPruningStrategy |
|
LazyExecutionLineageNode |
|
LazyExecutionLineageNode.Aggregator<T> |
|
LazyExecutionLineageNode.CollectingAggregator |
|
LibSVMTransform |
|
LimitedInputStream |
InputStream that is trimmed to a specified size.
|
Linear |
|
LinearRegressionMapping |
|
LinearRegressionModel |
|
LinearRegressionOperator |
|
LineItemTuple |
A tuple of the lineitem table.
|
LineItemTuple.Parser |
Parses a LineItemTuple from a given CSV line (double quoted, comma-separated).
|
List2AttributesObjectSkinny<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>> |
Created by khayyzy on 5/28/16.
|
LoadEstimate |
|
LoadEstimator |
|
LoadEstimator.SinglePointEstimationFunction |
Functional interface for lambda expressions to express single-point load estimation functions.
|
LoadProfile |
|
LoadProfileEstimator |
Estimates the LoadProfile of some executable artifact that takes some input data quanta and produces them.
|
LoadProfileEstimators |
|
LoadProfileToTimeConverter |
|
LoadProfileToTimeConverter.ResourceTimeEstimateAggregator |
|
LoadToTimeConverter |
|
LocalCallbackSink<T> |
This sink executes a callback on each received data unit into a Java Collection .
|
LocalCallbackSinkMapping |
|
LocalCallbackSinkMapping |
|
LocalCallbackSinkMapping |
|
LocalFileSystem |
FileSystem implementation for the local file system.
|
LocalStage |
|
LogEvaluator |
|
Logging |
Provide logging via Logger .
|
LogicalOperator |
An ML4all logical operator
|
LogicalOperatorWrapper<R,V> |
|
LogicalOperatorWrapperWithModel<R,V> |
Logical Operator that uses the [[org.apache.wayang.ml4all.abstraction.plan.ML4allModel]] as input besides the data flowing from its input slot.
|
Loop<R,V> |
|
LoopCheckWrapper<V> |
|
LoopConvergenceWrapper<R,V> |
|
LoopEnumerator |
|
LoopHeadAlternative |
|
LoopHeadAlternativeCardinalityPusher |
|
LoopHeadOperator |
|
LoopHeadOperator.State |
LoopHeadOperator s can be stateful because they might be executed mulitple times.
|
LoopImplementation |
|
LoopIsolator |
|
LoopMapping |
|
LoopMapping |
|
LoopMapping |
|
LoopOperator<InputType,ConvergenceType> |
This operator has three inputs and three outputs.
|
LoopSubplan |
|
LoopSubplanCardinalityPusher |
|
LruCache<K,V> |
Key-value cache with "least recently used" eviction strategy.
|
Main |
|
Main |
Starts a profiling run of Spark.
|
MapBasedKeyValueProvider<Key,Value> |
|
MapFunctionAdapter<InputType,OutputType> |
Wraps a Function as a Function .
|
MapMapping |
|
MapMapping |
|
MapMapping |
|
MapOperator<InputType,OutputType> |
A map operator represents semantics as they are known from frameworks, such as Spark and Flink.
|
MapPartitionsDescriptor<Input,Output> |
This descriptor pertains to functions that consume and output multiple data quanta.
|
MapPartitionsFunctionAdapter<InputType,OutputType> |
Wraps a Function as a FlatMapFunction .
|
MapPartitionsMapping |
|
MapPartitionsMapping |
|
MapPartitionsMapping |
|
MapPartitionsOperator<InputType,OutputType> |
This operator takes as input potentially multiple input data quanta and outputs multiple input data quanta.
|
Mapping |
|
Mappings |
Register for the components provided in the basic plugin.
|
Mappings |
Register for Mapping s for this platform.
|
Mappings |
Register for the Mapping s supported for this platform.
|
Mappings |
Register for Mapping s for this platform.
|
Mappings |
|
Mappings |
Register for Mapping s for this platform.
|
Mappings |
Register for the Mapping s supported for this platform.
|
Mappings |
Register for Mapping s for this platform.
|
Mappings |
Register for the Mapping s supported for this platform.
|
Mappings |
Register for Mapping s for this platform.
|
MaterializedGroupByMapping |
|
MaterializedGroupByMapping |
|
MaterializedGroupByMapping |
|
MaterializedGroupByMapping |
|
MaterializedGroupByOperator<Type,Key> |
This operator collocates the data units in a data set w.r.t. a key function.
|
MathExBaseListener |
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.
|
MathExBaseVisitor<T> |
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.
|
MathExException |
This exception signals a failed Expression evaluation.
|
MathExLexer |
|
MathExListener |
This interface defines a complete listener for a parse tree produced by
MathExParser .
|
MathExParser |
|
MathExParser.BinaryOperationContext |
|
MathExParser.ConstantContext |
|
MathExParser.ExpressionContext |
|
MathExParser.FunctionContext |
|
MathExParser.ParensExpressionContext |
|
MathExParser.UnaryOperationContext |
|
MathExParser.VariableContext |
|
MathExVisitor<T> |
This interface defines a complete generic visitor for a parse tree produced
by MathExParser .
|
Mean |
|
Measurement |
Measurement captures the value of a metric at a specific time
|
MeasurementDeserializer |
Custom deserializer for Measurement s
Detects actual subclass of serialized instances and then delegates the deserialization to that subtype.
|
MeasurementSerializer |
Custom serializer for Measurement s
Detects actual subclass of given instances, encodes this class membership, and then delegates serialization to that subtype.
|
ML4allModel |
For keeping global variables to access in the logical operators.
|
ML4allPlan |
Wayang physical plan for ML4all algorithms
|
Model |
A Type that represents a ML model
|
ModelParser |
|
ModelTransformMapping |
Deprecated. |
ModelTransformOperator<X,Y> |
Deprecated. |
Monitor |
|
MultiMap<K,V> |
Maps keys to multiple values.
|
myMergeSort<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input> |
Created by khayyzy on 5/28/16.
|
myMergeSort<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>> |
Created by khayyzy on 5/28/16.
|
NamedFunction |
Expression implementation that represents a function that is identified
via its name.
|
NestableLoadProfileEstimator |
|
NoInstrumentationStrategy |
Instruments only outbound Channel s.
|
NoIterationBreakpoint |
|
ObjectFileSink<T> |
This UnarySink writes all incoming data quanta to a Object file.
|
ObjectFileSinkMapping |
|
ObjectFileSinkMapping |
|
ObjectFileSinkMapping |
|
ObjectFileSource<T> |
This source reads a text file and outputs the lines as data units.
|
ObjectFileSourceMapping |
|
ObjectFileSourceMapping |
|
ObjectFileSourceMapping |
|
OneTimeExecutable |
Method wrapper that ensures that it is called only once.
|
Op |
|
Op.DType |
|
Operator |
|
OperatorAlternative |
This operator encapsulates operators that are alternative to each other.
|
OperatorAlternativeCardinalityPusher |
|
OperatorBase |
Helper class for the implementation of the Operator interface.
|
OperatorBase.GsonSerializer |
|
OperatorContainer |
This is not an Operator in its own right.
|
OperatorContainers |
|
OperatorMatch |
|
OperatorPattern<T extends Operator> |
An operator pattern matches to a class of operator instances.
|
OperatorProfiler |
|
OperatorProfiler.Result |
The result of a single profiling run.
|
OperatorProfilers |
|
OperatorProfilers |
|
Operators |
|
OptimizationContext |
Manages contextual information required during the optimization of a WayangPlan .
|
OptimizationSpace |
|
OptimizationUtils |
Utility methods for the optimization process.
|
Optimizer |
|
Optimizer |
|
Optimizer.ConfigProperties |
|
Optional<T> |
Utility similar to Optional .
|
OutboundInstrumentationStrategy |
Instruments only outbound Channel s.
|
OutputFormatConsumer<T> |
Wrapper for OutputFormat
|
OutputSerializer |
|
OutputSlot<T> |
An output slot declares an output of an Operator .
|
PageRankAlgorithm |
Basic PageRank implementation.
|
PageRankAlgorithm.PageRankMasterCompute |
|
PageRankAlgorithm.PageRankVertexInputFormat |
|
PageRankAlgorithm.PageRankVertexOutputFormat |
|
PageRankAlgorithm.PageRankVertexReader |
|
PageRankAlgorithm.PageRankWorkerContext |
|
PageRankMapping |
|
PageRankMapping |
|
PageRankMapping |
|
PageRankMapping |
|
PageRankMapping |
Mapping from PageRankOperator to org.apache.wayang.spark.operators.graph.SparkPageRankOperator .
|
PageRankMapping.RankInitializer |
Creates intial page ranks.
|
PageRankOperator |
|
PageRankParameters |
Parameters for Basic PageRank implementation.
|
PageRankParameters.PageRankEnum |
|
ParseException |
This exception signals a failed Expression evaluation.
|
PartialExecution |
|
PartialExecution.Serializer |
|
PartialExecutionMeasurement |
|
PlanEnumeration |
|
PlanEnumerationPruningStrategy |
|
PlanEnumerator |
|
PlanEnumerator.EnumerationActivator |
An Operator can be activated as soon as all of its inputs are available.
|
PlanImplementation |
Represents a partial execution plan.
|
PlanMetrics |
|
PlanTransformation |
|
PlanTraversal |
Traverse a plan.
|
PlanTraversal.Callback |
A callback can be invoked during a plan traversal on each traversed node.
|
PlanTraversal.SimpleCallback |
A callback can be invoked during a plan traversal on each traversed node.
|
Platform |
|
PlatformExecution |
Complete data flow on a single platform, that consists of multiple ExecutionStage s.
|
Platforms |
|
Plugin |
|
Postgres |
Register for relevant components of this module.
|
PostgresConversionsPlugin |
|
PostgresExecutionOperator |
|
PostgresFilterOperator |
|
PostgresJoinOperator<KeyType> |
|
PostgresPlatform |
|
PostgresPlugin |
|
PostgresProjectionOperator |
|
PostgresTableSource |
|
PredicateAdapter<InputType> |
Wraps a Predicate as a Function .
|
PredicateDescriptor<Input> |
This descriptor pertains to predicates that consume a single data unit.
|
PredictMapping |
|
PredictMapping |
|
PredictOperator<X,Y> |
|
PredictOperators |
|
PrintUtils |
|
ProbabilisticDoubleInterval |
An value representation that is capable of expressing uncertainty.
|
ProbabilisticIntervalEstimate |
An estimate that is capable of expressing uncertainty.
|
ProcessFeeder<Input,Output> |
|
ProcessReceiver<Output> |
|
ProfileDB |
This class provides facilities to save and load Experiment s.
|
ProfileDBs |
|
Profiler |
|
ProfilingUtils |
Utilities to fake Wayang internals etc..
|
ProjectionDescriptor<Input,Output> |
This descriptor pertains to projections.
|
ProjectionMapping |
|
ProjectionMapping |
|
ProjectionMapping |
|
PushExecutorTemplate |
|
PythonAPI |
|
PythonProcessCaller |
|
PythonWorkerManager<Input,Output> |
|
PyWayangReduceByOperator<Type,Key> |
|
RandomPruningStrategy |
|
RddChannel |
Describes the situation where one JavaRDD is operated on, producing a further JavaRDD .
|
ReaderIterator<Output> |
|
Record |
A Type that represents a record with a schema, might be replaced with something standard like JPA entity.
|
RecordType |
|
ReduceByMapping |
|
ReduceByMapping |
|
ReduceByMapping |
|
ReduceByMapping |
|
ReduceByOperator<Type,Key> |
This operator groups the elements of a data set and aggregates the groups.
|
ReduceDescriptor<Type> |
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..
|
ReduceOperator<Type> |
|
ReduceWrapper<T> |
|
ReferenceCountable |
This interface provides a reference-counting scheme, e.g., to manage allocated external resources.
|
ReflectionUtils |
Utilities for reflection code.
|
ReLU |
|
RepeatMapping |
|
RepeatMapping |
|
RepeatMapping |
|
RepeatMapping |
|
RepeatOperator<Type> |
This Operator repeats a certain subplan of Operator s for a given number of times.
|
ReplacementSubplanFactory |
|
ReplacementSubplanFactory.OfSingleOperators<MatchedOperator extends Operator> |
|
ReservoirSampler<T> |
Utility to do reservoir sampling with competitions over shared space.
|
ReturnTuple |
Tuple that is returned by Query 1.
|
revDataComparator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input> |
|
revDataComparator |
|
RrdAccessor |
Utility to read from an RRD file.
|
RunKMeans |
|
RunSGD |
|
S3FileSystem |
|
Sample |
|
SampleMapping |
|
SampleMapping |
|
SampleMapping |
|
SampleOperator<Type> |
A random sample operator randomly selects its inputs from the input slot and pushes that element to the output slot.
|
SampleOperator.Methods |
|
Sampler<T> |
Interface that describes a sampling algorithm that can give bias towards certain elements..
|
SanityChecker |
|
SchemaUtils |
|
SerializableObject |
The SerializableObject interface is a marker interface that indicates
that its implementing classes are serializable.
|
SGDImpl |
This class executes a stochastic gradient descent optimization on Apache Wayang (incubating).
|
SGDImprovedImpl |
This class executes a stochastic gradient descent optimization on Apache Wayang (incubating), just like SGDImpl .
|
SGDLoop |
|
SGDSample |
|
SGDStageWithZeros |
|
Sigmoid |
|
SimpleEstimationContext |
This EstimationContext implementation just stores all required variables without any further logic.
|
SinglePlatformPruningStrategy |
|
SinkProfiler |
|
SinkProfiler |
|
Slot<T> |
Abstract class for inputs and outputs to operators.
|
SlotMapping |
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).
|
Softmax |
|
SortMapping |
|
SortMapping |
|
SortMapping |
|
SortOperator<Type,Key> |
This operator sorts the elements in this dataset.
|
SourceProfiler |
|
Spark |
Register for relevant components of this module.
|
SparkBasicPlugin |
|
SparkBernoulliSampleOperator<Type> |
|
SparkBroadcastOperator<Type> |
Takes care of creating a Broadcast that can be used later on.
|
SparkCacheOperator<Type> |
|
SparkCartesianOperator<InputType0,InputType1> |
|
SparkCoGroupOperator<In0,In1,Key> |
|
SparkCollectionSource<Type> |
Provides a Collection to a Spark job.
|
SparkCollectionSourceProfiler |
|
SparkCollectOperator<Type> |
|
SparkContextReference |
Wraps and manages a JavaSparkContext to avoid steady re-creation.
|
SparkConversionPlugin |
This Plugin enables to create RDD s.
|
SparkCountOperator<Type> |
|
SparkDecisionTreeClassificationOperator |
|
SparkDecisionTreeClassificationOperator.Model |
|
SparkDistinctOperator<Type> |
|
SparkDoWhileOperator<InputType,ConvergenceType> |
|
SparkExecutionContext |
|
SparkExecutionOperator |
|
SparkExecutor |
|
SparkFilterOperator<Type> |
|
SparkFlatMapOperator<InputType,OutputType> |
|
SparkGlobalMaterializedGroupOperator<Type> |
|
SparkGlobalReduceOperator<Type> |
|
SparkGraphPlugin |
|
SparkIEJoinOperator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input extends Copyable<Input>> |
|
SparkIESelfJoinOperator<Type0 extends java.lang.Comparable<Type0>,Type1 extends java.lang.Comparable<Type1>,Input extends Copyable<Input>> |
|
SparkIntersectOperator<Type> |
|
SparkJoinOperator<InputType0,InputType1,KeyType> |
|
SparkKafkaTopicSink<T> |
|
SparkKafkaTopicSource |
Provides a Collection to a Spark job.
|
SparkKMeansOperator |
|
SparkKMeansOperator.Model |
|
SparkLinearRegressionOperator |
|
SparkLinearRegressionOperator.Model |
|
SparkListener |
A Spark listener implementation that captures events generated during the Spark job execution
and sends them to a Kafka topic for further processing.
|
SparkLocalCallbackSink<T extends java.io.Serializable> |
|
SparkLoopOperator<InputType,ConvergenceType> |
|
SparkMapOperator<InputType,OutputType> |
|
SparkMapPartitionsOperator<InputType,OutputType> |
|
SparkMaterializedGroupByOperator<Type,KeyType> |
|
SparkMLModel<X,Y> |
|
SparkMLPlugin |
|
SparkModelTransformOperator<X,Y> |
Deprecated. |
SparkObjectFileSink<T> |
|
SparkObjectFileSource<T> |
|
SparkOperatorProfiler |
|
SparkOperatorProfiler.Result |
The result of a single profiling run.
|
SparkPlatform |
|
SparkPredictOperator<X,Y> |
|
SparkRandomPartitionSampleOperator<Type> |
|
SparkReduceByOperator<Type,KeyType> |
|
SparkRepeatOperator<Type> |
|
SparkShufflePartitionSampleOperator<Type> |
|
SparkSortOperator<Type,Key> |
|
SparkSourceProfiler |
|
SparkTextFileSink<T> |
Implementation of the TextFileSink operator for the Spark platform.
|
SparkTextFileSource |
Provides a Collection to a Spark job.
|
SparkTextFileSourceProfiler |
|
SparkTsvFileSink<T extends Tuple2<?,?>> |
|
SparkTsvFileSource<T> |
|
SparkUnaryOperatorProfiler |
|
SparkUnionAllOperator<Type> |
|
SparkZipWithIdOperator<InputType> |
|
SparseVector |
|
SqlContext |
|
Sqlite3 |
Register for relevant components of this module.
|
Sqlite3ConversionPlugin |
|
Sqlite3FilterOperator |
|
Sqlite3Platform |
|
Sqlite3Plugin |
|
Sqlite3ProjectionOperator |
|
Sqlite3TableSource |
|
SqlQueryChannel |
Implementation of a Channel that is given by a SQL query.
|
SqlQueryChannel.Descriptor |
|
SqlToRddOperator |
|
SqlToStreamOperator |
|
SqlToStreamOperator.ResultSetIterator |
Exposes a ResultSet as an Iterator .
|
Stage |
This interface represents a stage in a data processing pipeline.
|
StageAssignmentTraversal |
|
StageAssignmentTraversal.StageSplittingCriterion |
Criterion to futher split StageAssignmentTraversal.InterimStage besides precedence.
|
StageCompleted |
Represents a completed stage in a distributed computing system.
|
StageExecutorMetrics |
The StageExecutorMetrics class implements the Stage and SerializableObject interfaces and represents
the metrics associated with a stage executed by an executor.
|
StageSubmitted |
The StageSubmitted class implements the Stage and SerializableObject interfaces to represent a submitted stage in a distributed system.
|
StopWatch |
|
Storage |
Controls how conducted experiments will be persisted and loaded
|
StreamChannel |
|
StringUtil |
|
Subject |
The subject of an Experiment , e.g., an application or algorithm.
|
Subplan |
A subplan encapsulates connected operators as a single operator.
|
SubplanCardinalityPusher |
|
SubplanMatch |
A subplan match correlates a SubplanPattern with its actually matched .
|
SubplanPattern |
A subplan pattern describes a class of subplans in a WayangPlan .
|
SwitchForwardCardinalityEstimator |
|
TableSource |
UnarySource that provides the tuples from a database table.
|
Task |
The Task interface represents a task in a distributed computing or data processing system.
|
Task.TaskStatusForRunning |
The TaskStatusForRunning enum represents the possible statuses of a task while it is running.
|
TaskEnd |
Represents the end status of a task execution.
|
TaskGettingResult |
Represents the getting results of a task execution.
|
TaskMetric |
The TaskMetric interface defines the methods used to set and retrieve
performance metrics for a given task.
|
TaskMetric |
This class represents the metrics for a task in the Apache Wayang monitoring system.
|
TaskStart |
Represents the start status of a task execution.
|
TensorChannel |
|
Tensorflow |
Register for relevant components of this module.
|
TensorflowCollectionSource<Type> |
Provides a Collection to a Tensorflow job.
|
TensorflowCollectOperator<Type> |
|
TensorflowContextReference |
|
TensorflowConversionPlugin |
|
TensorflowDLTrainingOperator |
|
TensorflowExecutionOperator |
|
TensorflowExecutor |
|
TensorflowModel |
|
TensorflowPlatform |
|
TensorflowPlugin |
|
TensorflowPredictOperator |
|
TextFileSink<T> |
This UnarySink writes all incoming data quanta to a text file.
|
TextFileSinkMapping |
|
TextFileSinkMapping |
|
TextFileSinkMapping |
|
TextFileSource |
This source reads a text file and outputs the lines as data units.
|
TextFileSourceMapping |
|
TextFileSourceMapping |
|
TextFileSourceMapping |
|
TimeEstimate |
|
TimeMeasurement |
A Measurement that captures a certain amount of time in milliseconds.
|
TimeToCostConverter |
This (linear) converter turns TimeEstimate s into cost estimates.
|
TopDownPlanVisitor<Payload,Return> |
Visitor (as in the Visitor Pattern) for WayangPlan s.
|
TopKPruningStrategy |
|
TournamentSampler<T> |
Sampling strategy that simulates a tournament between elements.
|
TPCHQ1WithJavaNative |
Main class for the TPC-H app based on Apache Wayang (incubating).
|
Transform<R,V> |
|
TransformationDescriptor<Input,Output> |
This descriptor pertains to functions that consume a single data unit and output a single data unit.
|
TransformCSV |
|
TransformPerPartitionWrapper<R,V> |
|
TransformWrapper<R,V> |
|
Tuple<T0,T1> |
A helper data structure to manage two values without creating new classes.
|
Tuple2<T0,T1> |
A type for tuples.
|
Tuple5<T0,T1,T2,T3,T4> |
A type for tuples.
|
Type |
|
TypeConverter |
|
UnaryOperation |
|
UnaryOperatorProfiler |
|
UnarySink<T> |
Abstract base-class for sinks with a single input.
|
UnarySource<T> |
Abstract base class for sources with a single output.
|
UnaryToUnaryOperator<InputType,OutputType> |
This operator has a single input and a single output.
|
UnionAllMapping |
|
UnionAllMapping |
|
UnionAllMapping |
|
UnionAllOperator<Type> |
This Operator creates the union (bag semantics) of two .
|
Update<R,V> |
|
UpdateLocal<R,V> |
|
UpdateLocalWrapper<R,V> |
|
UpdateWrapper<R,V> |
|
Util |
|
ValueProvider<Value> |
|
ValueProvider.NotAvailableException |
|
Variable |
|
Variable |
A variable that can be altered by an optimization algorithm.
|
WayangAggregate |
|
WayangAggregateVisitor |
|
WayangAggregator |
Class create a Aggregator that generate aggregatorWrapper
|
WayangArrays |
Utility for handling arrays.
|
WayangBasic |
Activator for the basic Wayang package.
|
WayangBasicGraph |
Activator for graph operations being executed with Wayang's basic operators.
|
WayangBasics |
Register for plugins in the module.
|
WayangCollections |
Utilities to operate Collection s.
|
WayangContext |
This is the entry point for users to work with Wayang.
|
WayangConvention |
|
WayangConvergenceCriterion<T> |
Class create a ConvergenceCriterion that generate aggregatorWrapper
|
WayangException |
Exception that declares a problem of Wayang.
|
WayangFileOutputFormat<IT> |
Wrapper for FileOutputFormat
|
WayangFilter |
|
WayangFilterCriterion<T> |
Class create a FilterFunction for use inside of the LoopOperators
|
WayangFilterVisitor |
|
WayangJoin |
|
WayangJoinVisitor |
|
WayangJsonArray |
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
|
WayangJsonObj |
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
|
WayangListValue |
Is a Wrapper for used in the criterion of the Loops
|
WayangPlan |
A Wayang plan consists of a set of Operator s.
|
WayangProgram |
|
WayangProject |
|
WayangProjectVisitor |
|
WayangRel |
|
WayangRelConverter |
|
WayangRules |
|
WayangSchema |
|
WayangSchemaBuilder |
|
WayangTable |
|
WayangTableBuilder |
|
WayangTableScan |
|
WayangTableScanVisitor |
|
WayangTableStatistic |
|
WayangValue<T> |
Implementation of Value of flink for use in Wayang
|
WeightsUpdate |
|
WordCount |
|
WordCount |
|
WordCountOnKafkaTopic |
|
WordCountWithJavaNativeAPI |
Example Apache Wayang (incubating) App that does a word count -- the Hello World of Map/Reduce-like systems.
|
WrappedFlatMapDescriptor<Input,Output> |
|
WrappedMapPartitionsDescriptor<Input,Output> |
|
WrappedPredicateDescriptor<Input> |
|
WrappedPythonFunction<Input,Output> |
|
WrappedReduceDescriptor<Type> |
|
WrappedTransformationDescriptor<Input,Output> |
|
ZeroMQMonitor |
TODO: Implement
|
ZipWithIdMapping |
|
ZipWithIdMapping |
|
ZipWithIdMapping |
|
ZipWithIdOperator<InputType> |
This operators attaches a unique ID to each input data quantum.
|