- AbsentBlockException - Exception in edu.snu.coral.runtime.common.exception
-
An exception which represents the requested block is neither COMMITTED nor SCHEDULED.
- AbsentBlockException(String, BlockState.State) - Constructor for exception edu.snu.coral.runtime.common.exception.AbsentBlockException
-
- AbstractBlockStore - Class in edu.snu.coral.runtime.executor.data.stores
-
This abstract class represents a default
BlockStore
,
which contains other components used in each implementation of
BlockStore
.
- AbstractBlockStore(CoderManager) - Constructor for class edu.snu.coral.runtime.executor.data.stores.AbstractBlockStore
-
Constructor.
- accumulateBarrierMetric(List<Long>, String, String) - Method in class edu.snu.coral.runtime.master.RuntimeMaster
-
Accumulates the metric data for a barrier vertex.
- accumulateMetric(String, List<T>) - Method in class edu.snu.coral.common.ir.vertex.MetricCollectionBarrierVertex
-
Method for accumulating metrics in the vertex.
- ActiveContextHandler() - Constructor for class edu.snu.coral.driver.CoralDriver.ActiveContextHandler
-
- addDAGDirectory(String) - Method in class edu.snu.coral.common.ArgBuilder
-
- addDagIncomingEdge(IREdge) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Adds the incoming edge of the contained DAG.
- addDagOutgoingEdge(IREdge) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Adds and outgoing edge of the contained DAG.
- addInput(List<Pair<List<Integer>, List<Double>>>, Pair<List<Integer>, List<Double>>) - Method in class edu.snu.coral.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
-
- addIterativeIncomingEdge(IREdge) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Adds an iterative incoming edge, from the previous iteration, but connection internally.
- addJobId(String) - Method in class edu.snu.coral.common.ArgBuilder
-
- addNonIterativeIncomingEdge(IREdge) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Adds a non-iterative incoming edge, from outside the previous iteration.
- addOptimizationPolicy(String) - Method in class edu.snu.coral.common.ArgBuilder
-
- addState(Enum, String) - Method in class edu.snu.coral.common.StateMachine.Builder
-
Adds a state with name and description.
- addTransition(Enum, Enum, String) - Method in class edu.snu.coral.common.StateMachine.Builder
-
Adds a transition with description.
- addUserArgs(String...) - Method in class edu.snu.coral.common.ArgBuilder
-
- addUserMain(String) - Method in class edu.snu.coral.common.ArgBuilder
-
- addVertex(V) - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Add vertex to the builder.
- addVertex(V, Stack<LoopVertex>) - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Add vertex to the builder, using the LoopVertex stack.
- addVertex(V, DAG<V, E>) - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Add vertex to the builder, using the information from the given DAG.
- addVertex(IRVertex) - Method in class edu.snu.coral.runtime.common.plan.stage.StageBuilder
-
- aggregate(U, Function2<U, T, U>, Function2<U, U, U>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- all() - Static method in class edu.snu.coral.runtime.common.data.HashRange
-
- AllocatedEvaluatorHandler() - Constructor for class edu.snu.coral.driver.CoralDriver.AllocatedEvaluatorHandler
-
- AlternatingLeastSquare - Class in edu.snu.coral.examples.beam
-
Sample Alternating Least Square application.
- AlternatingLeastSquare.CalculateNextMatrix - Class in edu.snu.coral.examples.beam
-
DoFn for calculating next matrix at each iteration.
- AlternatingLeastSquare.ParseLine - Class in edu.snu.coral.examples.beam
-
Method for parsing the input line.
- AlternatingLeastSquare.TrainingDataCombiner - Class in edu.snu.coral.examples.beam
-
Combiner for the training data.
- AlternatingLeastSquare.UngroupSingleVectorList - Class in edu.snu.coral.examples.beam
-
A DoFn that relays a single vector list.
- AlternatingLeastSquare.UpdateUserAndItemMatrix - Class in edu.snu.coral.examples.beam
-
Composite transform that wraps the transforms inside the loop.
- AlternatingLeastSquareInefficient - Class in edu.snu.coral.examples.beam
-
Sample Alternating Least Square application.
- AlternatingLeastSquareInefficient.UpdateUserAndItemMatrix - Class in edu.snu.coral.examples.beam
-
Composite transform that wraps the transforms inside the loop.
- AnnotatingPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A compile-time pass that annotates the IR DAG with execution properties.
- AnnotatingPass(ExecutionProperty.Key, Set<ExecutionProperty.Key>) - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.AnnotatingPass
-
Constructor.
- AnnotatingPass(ExecutionProperty.Key) - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.AnnotatingPass
-
Constructor.
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.CompressionPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewEdgeDataStorePass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewEdgeMetricCollectionPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewEdgePartitionerPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewVertexPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DefaultEdgeUsedDataHandlingPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DefaultStagePartitioningPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DisaggregationEdgeDataStorePass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.PadoEdgeDataFlowModelPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.PadoEdgeDataStorePass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.PadoVertexExecutorPlacementPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.ReviseInterStageEdgeDataStorePass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.SailfishEdgeDataFlowModelPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.SailfishEdgeDataStorePass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.SailfishEdgeUsedDataHandlingPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.ScheduleGroupPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.ShuffleEdgePushPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.CompositePass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.CommonSubexpressionEliminationPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.DataSkewReshapingPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.LoopExtractionPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations.LoopFusionPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations.LoopInvariantCodeMotionPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.LoopUnrollingPass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.SailfishRelayReshapingPass
-
- apply(List<Double>, List<Double>) - Method in class edu.snu.coral.examples.beam.MultinomialLogisticRegression.CombineFunction
-
- apply(Iterable<List<Double>>) - Method in class edu.snu.coral.examples.beam.MultinomialLogisticRegression.CombineFunctionForIterable
-
- apply(PhysicalPlan, Map<String, List<Long>>) - Method in class edu.snu.coral.runtime.common.optimizer.pass.runtime.DataSkewRuntimePass
-
- apply(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalPlanGenerator
-
- appName(String) - Method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession.Builder
-
- ArgBuilder - Class in edu.snu.coral.common
-
Argument builder.
- ArgBuilder() - Constructor for class edu.snu.coral.common.ArgBuilder
-
- asFileAreas(KeyRange) - Method in class edu.snu.coral.runtime.executor.data.block.FileBlock
-
- asyncConnect(String, String) - Method in class edu.snu.coral.runtime.common.message.grpc.GrpcMessageEnvironment
-
- asyncConnect(String, String) - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageEnvironment
-
- asyncConnect(String, String) - Method in interface edu.snu.coral.runtime.common.message.MessageEnvironment
-
Asynchronously connect to the node called
receiverId
and return a future of
MessageSender
that sends messages to the listener with
listenerId
.
- asyncConnect(String, String) - Method in class edu.snu.coral.runtime.common.message.ncs.NcsMessageEnvironment
-
- Backend<Plan> - Interface in edu.snu.coral.compiler.backend
-
Interface for backend components.
- BatchSingleJobScheduler - Class in edu.snu.coral.runtime.master.scheduler
-
BatchSingleJobScheduler receives a single
PhysicalPlan
to execute and schedules the TaskGroups.
- BatchSingleJobScheduler(SchedulingPolicy, SchedulerRunner, PendingTaskGroupQueue, BlockManagerMaster, PubSubEventHandlerWrapper, UpdatePhysicalPlanEventHandler) - Constructor for class edu.snu.coral.runtime.master.scheduler.BatchSingleJobScheduler
-
- BeamBoundedSourceVertex<O> - Class in edu.snu.coral.compiler.frontend.beam.source
-
SourceVertex implementation for BoundedSource.
- BeamBoundedSourceVertex(BoundedSource<O>) - Constructor for class edu.snu.coral.compiler.frontend.beam.source.BeamBoundedSourceVertex
-
Constructor of BeamBoundedSourceVertex.
- BeamCoder<T> - Class in edu.snu.coral.compiler.frontend.beam.coder
-
- BeamCoder(Coder<T>) - Constructor for class edu.snu.coral.compiler.frontend.beam.coder.BeamCoder
-
Constructor of BeamCoder.
- BeamStateTranslator - Class in edu.snu.coral.compiler.frontend.beam
-
- BeamStateTranslator() - Constructor for class edu.snu.coral.compiler.frontend.beam.BeamStateTranslator
-
- beforeRequest(long) - Method in class edu.snu.coral.runtime.common.ReplyFutureMap
-
Called by message sender, just before a new request is sent.
- beginMeasurement(Map<String, Object>) - Method in class edu.snu.coral.runtime.common.metric.MetricDataBuilder
-
Begin the measurement of metric data.
- Block<K extends Serializable> - Interface in edu.snu.coral.runtime.executor.data.block
-
This interface represents a block, which is the output of a specific task.
- BLOCK_MANAGER_MASTER_MESSAGE_LISTENER_ID - Static variable in interface edu.snu.coral.runtime.common.message.MessageEnvironment
-
- BlockFetchException - Exception in edu.snu.coral.common.exception
-
BlockFetchException.
- BlockFetchException(Throwable) - Constructor for exception edu.snu.coral.common.exception.BlockFetchException
-
BlockFetchException.
- blockIdToFilePath(String, String) - Static method in class edu.snu.coral.runtime.executor.data.DataUtil
-
Converts a block id to the corresponding file path.
- blockIdToMetaFilePath(String, String) - Static method in class edu.snu.coral.runtime.executor.data.DataUtil
-
Converts a block id to the corresponding metadata file path.
- BlockInputStream<T> - Class in edu.snu.coral.runtime.executor.data.blocktransfer
-
Input stream for block transfer.
- BlockManagerMaster - Class in edu.snu.coral.runtime.master
-
Master-side block manager.
- BlockManagerMaster.PartitionManagerMasterControlMessageReceiver - Class in edu.snu.coral.runtime.master
-
Handler for control messages received.
- BlockManagerWorker - Class in edu.snu.coral.runtime.executor.data
-
Executor-side block manager.
- BlockOutputStream<T> - Class in edu.snu.coral.runtime.executor.data.blocktransfer
-
Output stream for block transfer.
- BlockState - Class in edu.snu.coral.runtime.common.state
-
Represents the states of a whole data(a task output).
- BlockState() - Constructor for class edu.snu.coral.runtime.common.state.BlockState
-
- BlockState.State - Enum in edu.snu.coral.runtime.common.state
-
BlockState.
- BlockStore - Interface in edu.snu.coral.runtime.executor.data.stores
-
Interface for
Block
placement.
- BlockStream - Interface in edu.snu.coral.runtime.executor.data.blocktransfer
-
- BlockTransfer - Class in edu.snu.coral.runtime.executor.data.blocktransfer
-
- BlockWriteException - Exception in edu.snu.coral.common.exception
-
BlockWriteException.
- BlockWriteException(Throwable) - Constructor for exception edu.snu.coral.common.exception.BlockWriteException
-
BlockWriteException.
- BoundedSourceTask<O> - Class in edu.snu.coral.runtime.common.plan.physical
-
BoundedSourceTask.
- BoundedSourceTask(String, String, ReadablesWrapper<O>) - Constructor for class edu.snu.coral.runtime.common.plan.physical.BoundedSourceTask
-
Constructor.
- Broadcast - Class in edu.snu.coral.examples.beam
-
Sample Broadcast application.
- build() - Method in class edu.snu.coral.common.ArgBuilder
-
- build() - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Build the DAG.
- build() - Method in class edu.snu.coral.common.StateMachine.Builder
-
Builds and returns the StateMachine.
- build() - Method in class edu.snu.coral.compiler.optimizer.policy.PolicyBuilder
-
Build a policy using compileTimePasses and runtimePasses in this object.
- build() - Method in class edu.snu.coral.runtime.common.metric.MetricDataBuilder
-
Builds immutable MetricData.
- build() - Method in class edu.snu.coral.runtime.common.plan.stage.StageBuilder
-
Builds and returns the
Stage
.
- build() - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
- build() - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification.Builder
-
- builder() - Static method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession
-
Get a builder for the session.
- Builder() - Constructor for class edu.snu.coral.compiler.frontend.spark.sql.SparkSession.Builder
-
- buildWithoutSourceSinkCheck() - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Build the DAG for LoopVertex.
- BytesCoder - Class in edu.snu.coral.common.coder
-
A
Coder
which is used for an array of bytes.
- BytesCoder() - Constructor for class edu.snu.coral.common.coder.BytesCoder
-
Constructor.
- cache() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- calculateHashRanges(Map<String, List<Long>>, Integer) - Method in class edu.snu.coral.runtime.common.optimizer.pass.runtime.DataSkewRuntimePass
-
Method for calculating key ranges to evenly distribute the skewed metric data.
- cancel() - Method in class edu.snu.coral.compiler.frontend.beam.CoralPipelineResult
-
- channelActive(ChannelHandlerContext) - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockTransfer
-
- channelInactive(ChannelHandlerContext) - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockTransfer
-
- channelRead0(ChannelHandlerContext, BlockStream) - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockTransfer
-
- checkJobTermination() - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- checkpoint() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- checkStageCompletion(String) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- checkState(Enum) - Method in class edu.snu.coral.common.StateMachine
-
Checks whether the current state is same as the expectedCurrentState
.
- ClientEndpoint - Class in edu.snu.coral.client
-
A request endpoint in client side of a job.
- ClientEndpoint(StateTranslator) - Constructor for class edu.snu.coral.client.ClientEndpoint
-
Constructor.
- ClosableBlockingQueue<T> - Class in edu.snu.coral.runtime.executor.data.blocktransfer
-
A blocking queue implementation which is capable of closing the input end.
- ClosableBlockingQueue() - Constructor for class edu.snu.coral.runtime.executor.data.blocktransfer.ClosableBlockingQueue
-
Creates a closable blocking queue.
- ClosableBlockingQueue(int) - Constructor for class edu.snu.coral.runtime.executor.data.blocktransfer.ClosableBlockingQueue
-
Creates a closable blocking queue.
- close() - Method in class edu.snu.coral.common.ir.vertex.transform.RelayTransform
-
- close() - Method in interface edu.snu.coral.common.ir.vertex.transform.Transform
-
Close the transform.
- close() - Method in class edu.snu.coral.compiler.frontend.beam.transform.CreateViewTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.beam.transform.DoTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.beam.transform.FlattenTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.beam.transform.GroupByKeyTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.beam.transform.WindowTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.spark.transform.CollectTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.spark.transform.FlatMapTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.spark.transform.GroupByKeyTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.spark.transform.MapToPairTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.spark.transform.MapTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.spark.transform.ReduceByKeyTransform
-
- close() - Method in class edu.snu.coral.compiler.frontend.spark.transform.ReduceTransform
-
- close() - Method in class edu.snu.coral.compiler.optimizer.examples.EmptyComponents.EmptyTransform
-
- close() - Method in class edu.snu.coral.driver.RemoteClientMessageLoggingHandler
-
- close() - Method in class edu.snu.coral.runtime.common.message.grpc.GrpcMessageEnvironment
-
- close() - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageEnvironment
-
- close() - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageSender
-
- close() - Method in interface edu.snu.coral.runtime.common.message.MessageEnvironment
-
Close this message environment.
- close() - Method in interface edu.snu.coral.runtime.common.message.MessageSender
-
Closes the connection.
- close() - Method in class edu.snu.coral.runtime.common.message.ncs.NcsMessageEnvironment
-
- close() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
Closes this stream.
- close() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.ClosableBlockingQueue
-
Mark the input end of this queue as closed.
- close() - Method in class edu.snu.coral.runtime.executor.datatransfer.OutputWriter
-
Notifies that all writes for a block is end.
- close() - Method in class edu.snu.coral.runtime.executor.MetricManagerWorker
-
- close() - Method in interface edu.snu.coral.runtime.executor.MetricMessageSender
-
- close() - Method in interface edu.snu.coral.runtime.master.scheduler.PendingTaskGroupQueue
-
Closes and cleans up this queue.
- close() - Method in class edu.snu.coral.runtime.master.scheduler.SingleJobTaskGroupQueue
-
- closeExceptionally(Throwable) - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
Closes this stream, exceptionally.
- coalesce(int) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- coalesce(int, boolean) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- Coder<T> - Interface in edu.snu.coral.common.coder
-
A
Coder<T>
object encodes or decodes values of type
T
into byte streams.
- Coder.DummyCoder - Class in edu.snu.coral.common.coder
-
Dummy coder implementation which is not supposed to be used.
- CoderManager - Class in edu.snu.coral.runtime.executor.data
-
Mapping from RuntimeEdgeId to Coder.
- CoderManager() - Constructor for class edu.snu.coral.runtime.executor.data.CoderManager
-
Constructor.
- collect() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaPairRDD
-
- collect() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- collect(DAG<IRVertex, IREdge>, Stack<LoopVertex>, IRVertex, Serializer) - Static method in class edu.snu.coral.compiler.frontend.spark.core.java.SparkFrontendUtils
-
Collect data by running the DAG.
- collectAsync() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- collectOutputList() - Method in class edu.snu.coral.runtime.executor.datatransfer.OutputCollectorImpl
-
Collects the accumulated output and replace the output list.
- collectPartitions(int[]) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- CollectTransform<T> - Class in edu.snu.coral.compiler.frontend.spark.transform
-
Collect transform.
- CollectTransform(String) - Constructor for class edu.snu.coral.compiler.frontend.spark.transform.CollectTransform
-
Constructor.
- CombineFunction() - Constructor for class edu.snu.coral.examples.beam.MultinomialLogisticRegression.CombineFunction
-
- CombineFunctionForIterable() - Constructor for class edu.snu.coral.examples.beam.MultinomialLogisticRegression.CombineFunctionForIterable
-
- combineFutures(List<CompletableFuture<Iterator>>) - Static method in class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
Combine the given list of futures.
- commit() - Method in interface edu.snu.coral.runtime.executor.data.block.Block
-
Commits this block to prevent further write.
- commit() - Method in class edu.snu.coral.runtime.executor.data.block.FileBlock
-
Commits this block to prevent further write.
- commit() - Method in class edu.snu.coral.runtime.executor.data.block.NonSerializedMemoryBlock
-
Commits this block to prevent further write.
- commit() - Method in class edu.snu.coral.runtime.executor.data.block.SerializedMemoryBlock
-
Commits this block to prevent further write.
- commitBlock(String, DataStoreProperty.Value, List<Long>, String, int, UsedDataHandlingProperty.Value) - Method in class edu.snu.coral.runtime.executor.data.BlockManagerWorker
-
Notifies that all writes for a block is end.
- commitBlock() - Method in class edu.snu.coral.runtime.executor.data.metadata.FileMetadata
-
Notifies that all writes are finished for the block corresponding to this metadata.
- commitBlock() - Method in class edu.snu.coral.runtime.executor.data.metadata.LocalFileMetadata
-
Notifies that all writes are finished for the block corresponding to this metadata.
- commitBlock() - Method in class edu.snu.coral.runtime.executor.data.metadata.RemoteFileMetadata
-
- commitBlock(String) - Method in interface edu.snu.coral.runtime.executor.data.stores.BlockStore
-
Notifies that all writes for a block is end.
- commitBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
Notifies that all writes for a block is end.
- commitBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalBlockStore
-
- CommonEventHandler<T> - Interface in edu.snu.coral.common.eventhandler
-
Class for handling common events.
- CommonSubexpressionEliminationPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping
-
Pass for Common Subexpression Elimination optimization.
- CommonSubexpressionEliminationPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.CommonSubexpressionEliminationPass
-
Default constructor.
- compareAndSetState(Enum, Enum) - Method in class edu.snu.coral.common.StateMachine
-
Atomically sets the state to the given updated state
if the current state equals to the expected state.
- compile(DAG<IRVertex, IREdge>) - Method in interface edu.snu.coral.compiler.backend.Backend
-
Compiles a DAG to a physical execution plan.
- compile(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.compiler.backend.coral.CoralBackend
-
Compiles an IR DAG into a
PhysicalPlan
to be submitted to Runtime.
- compile(DAG<IRVertex, IREdge>, PhysicalPlanGenerator) - Method in class edu.snu.coral.compiler.backend.coral.CoralBackend
-
Compiles an IR DAG into a
PhysicalPlan
to be submitted to Runtime.
- CompilerEvent - Interface in edu.snu.coral.common.eventhandler
-
An empty interface to indicate events that are sent from Compiler.
- CompilerEventHandler<T extends CompilerEvent> - Interface in edu.snu.coral.common.eventhandler
-
Class for handling events sent from Compiler.
- CompileTimeOptimizationException - Exception in edu.snu.coral.common.exception
-
DynamicOptimizationException.
- CompileTimeOptimizationException(Throwable) - Constructor for exception edu.snu.coral.common.exception.CompileTimeOptimizationException
-
Constructor of DynamicOptimizationException.
- CompileTimeOptimizationException(String) - Constructor for exception edu.snu.coral.common.exception.CompileTimeOptimizationException
-
Constructor of DynamicOptimizationException.
- CompiletimeOptimizer - Class in edu.snu.coral.compiler.optimizer
-
Compile time optimizer class.
- CompileTimePass - Interface in edu.snu.coral.compiler.optimizer.pass.compiletime
-
Interface for compile-time optimization passes that processes the DAG.
- CompositePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.composite
-
A compile-time pass composed of multiple compile-time passes, which each modifies an IR DAG.
- CompositePass(List<CompileTimePass>) - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.CompositePass
-
Constructor.
- CompressionPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A pass for applying compression algorithm for data flowing between vertices.
- CompressionPass(CompressionProperty.Compression) - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.CompressionPass
-
Default constructor.
- CompressionProperty - Class in edu.snu.coral.common.ir.edge.executionproperty
-
Compression ExecutionProperty.
- CompressionProperty.Compression - Enum in edu.snu.coral.common.ir.edge.executionproperty
-
Possible values of Compression ExecutionProperty.
- COMPUTE - Static variable in class edu.snu.coral.common.ir.vertex.executionproperty.ExecutorPlacementProperty
-
- compute(Partition, TaskContext) - Method in class edu.snu.coral.compiler.frontend.spark.core.RDD
-
- concatNonSerPartitions(Iterable<NonSerializedPartition>) - Static method in class edu.snu.coral.runtime.executor.data.DataUtil
-
Concatenates an iterable of non-serialized
Partition
s into a single iterable of elements.
- config(SparkConf) - Method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession.Builder
-
- config(String, String) - Method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession.Builder
-
- connectInternalVertices(IREdge) - Method in class edu.snu.coral.runtime.common.plan.stage.StageBuilder
-
- connectVertices(E) - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Connect vertices at the edge.
- consistentWithEquals() - Method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
- ContainerException - Exception in edu.snu.coral.common.exception
-
ContainerException.
- ContainerException(Throwable) - Constructor for exception edu.snu.coral.common.exception.ContainerException
-
ContainerException.
- ContainerManager - Class in edu.snu.coral.runtime.master.resource
-
Encapsulates REEF's evaluator management for executors.
- ContainerManager(int, EvaluatorRequestor, MessageEnvironment) - Constructor for class edu.snu.coral.runtime.master.resource.ContainerManager
-
- contains(V) - Method in class edu.snu.coral.common.dag.DAGBuilder
-
check if the DAGBuilder contains the vertex.
- contains(Predicate<V>) - Method in class edu.snu.coral.common.dag.DAGBuilder
-
check if the DAGBuilder contains any vertex that satisfies the predicate.
- containsKey(ExecutionProperty.Key) - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
- ContextImpl - Class in edu.snu.coral.common
-
Transform Context Implementation.
- ContextImpl(Map<Transform, Object>) - Constructor for class edu.snu.coral.common.ContextImpl
-
Constructor of Context Implementation.
- ContextStartHandler() - Constructor for class edu.snu.coral.driver.CoralContext.ContextStartHandler
-
- ContextStopHandler() - Constructor for class edu.snu.coral.driver.CoralContext.ContextStopHandler
-
- convert(Function<DAG<V, E>, DAG<V2, E2>>) - Method in class edu.snu.coral.common.dag.DAG
-
Converts a DAG into another DAG according to a function.
- convertBlockState(ControlMessage.BlockStateFromExecutor) - Static method in class edu.snu.coral.runtime.master.RuntimeMaster
-
- convertBlockState(BlockState.State) - Static method in class edu.snu.coral.runtime.master.RuntimeMaster
-
- convertToNonSerPartitions(Coder, Iterable<SerializedPartition<K>>) - Static method in class edu.snu.coral.runtime.executor.data.DataUtil
-
- convertToSerPartitions(Coder, Iterable<NonSerializedPartition<K>>) - Static method in class edu.snu.coral.runtime.executor.data.DataUtil
-
- copyExecutionPropertiesTo(IREdge) - Method in class edu.snu.coral.common.ir.edge.IREdge
-
Static function to copy executionProperties from an edge to the other.
- copyExecutionPropertiesTo(IRVertex) - Method in class edu.snu.coral.common.ir.vertex.IRVertex
-
Static function to copy executionProperties from a vertex to the other.
- CoralBackend - Class in edu.snu.coral.compiler.backend.coral
-
Backend component for Coral Runtime.
- CoralBackend() - Constructor for class edu.snu.coral.compiler.backend.coral.CoralBackend
-
Constructor.
- CoralClient - Class in edu.snu.coral.client
-
A wrapper class that contains client handlers.
- CoralClient.JobMessageHandler - Class in edu.snu.coral.client
-
Message handler.
- CoralContext - Class in edu.snu.coral.driver
-
REEF Context for the Executor.
- CoralContext.ContextStartHandler - Class in edu.snu.coral.driver
-
Called when the context starts.
- CoralContext.ContextStopHandler - Class in edu.snu.coral.driver
-
Called when the context is stopped.
- CoralDriver - Class in edu.snu.coral.driver
-
REEF Driver for Coral.
- CoralDriver.ActiveContextHandler - Class in edu.snu.coral.driver
-
Context active.
- CoralDriver.AllocatedEvaluatorHandler - Class in edu.snu.coral.driver
-
Container allocated.
- CoralDriver.DriverStopHandler - Class in edu.snu.coral.driver
-
Driver stopped.
- CoralDriver.FailedContextHandler - Class in edu.snu.coral.driver
-
Context failed.
- CoralDriver.FailedEvaluatorHandler - Class in edu.snu.coral.driver
-
Evaluator failed.
- CoralDriver.StartHandler - Class in edu.snu.coral.driver
-
Driver started.
- CoralPipelineOptions - Interface in edu.snu.coral.compiler.frontend.beam
-
CoralPipelineOptions.
- CoralPipelineResult - Class in edu.snu.coral.compiler.frontend.beam
-
Beam result.
- CoralPipelineResult() - Constructor for class edu.snu.coral.compiler.frontend.beam.CoralPipelineResult
-
Default constructor.
- CoralPipelineRunner - Class in edu.snu.coral.compiler.frontend.beam
-
Runner class for BEAM programs.
- CoralPipelineVisitor - Class in edu.snu.coral.compiler.frontend.beam
-
Visits every node in the beam dag to translate the BEAM program to the IR.
- CoralPipelineVisitor(DAGBuilder<IRVertex, IREdge>, PipelineOptions) - Constructor for class edu.snu.coral.compiler.frontend.beam.CoralPipelineVisitor
-
Constructor of the BEAM Visitor.
- count() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- countApprox(long) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- countApprox(long, double) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- countApproxDistinct(double) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- countAsync() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- countByValue() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- countByValueApprox(long) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- countByValueApprox(long, double) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- create(String) - Static method in class edu.snu.coral.runtime.executor.data.metadata.RemoteFileMetadata
-
Creates a new block metadata.
- createAccumulator() - Method in class edu.snu.coral.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
-
- createBlock(String, DataStoreProperty.Value) - Method in class edu.snu.coral.runtime.executor.data.BlockManagerWorker
-
Creates a new block.
- createBlock(String) - Method in interface edu.snu.coral.runtime.executor.data.stores.BlockStore
-
Creates a new block.
- createBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
Creates a new block.
- createBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalFileStore
-
Creates a new block.
- createBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.MemoryStore
-
- createBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.SerializedMemoryStore
-
- createLocalReader(int, RuntimeEdge) - Method in class edu.snu.coral.runtime.executor.datatransfer.DataTransferFactory
-
Creates a local
InputReader
between two task in a single task group.
- createLocalWriter(Task, int, RuntimeEdge<?>) - Method in class edu.snu.coral.runtime.executor.datatransfer.DataTransferFactory
-
Creates an local
OutputWriter
between two task in a single task group.
- createReader(int, IRVertex, RuntimeEdge) - Method in class edu.snu.coral.runtime.executor.datatransfer.DataTransferFactory
-
- CreateViewTransform<I,O> - Class in edu.snu.coral.compiler.frontend.beam.transform
-
CreateView transform implementation.
- CreateViewTransform(PCollectionView<O>) - Constructor for class edu.snu.coral.compiler.frontend.beam.transform.CreateViewTransform
-
Constructor of CreateViewTransform.
- createWriter(Task, int, IRVertex, RuntimeEdge<?>) - Method in class edu.snu.coral.runtime.executor.datatransfer.DataTransferFactory
-
- DAG<V extends Vertex,E extends Edge<V>> - Class in edu.snu.coral.common.dag
-
DAG implementation.
- DAG(Set<V>, Map<V, Set<E>>, Map<V, Set<E>>, Map<V, LoopVertex>, Map<V, Integer>) - Constructor for class edu.snu.coral.common.dag.DAG
-
Constructor of DAG, called by the DAGBuilder.
- DAG.TraversalOrder - Enum in edu.snu.coral.common.dag
-
Indicates the traversal order of this DAG.
- DAGBuilder<V extends Vertex,E extends Edge<V>> - Class in edu.snu.coral.common.dag
-
DAG Builder.
- DAGBuilder() - Constructor for class edu.snu.coral.common.dag.DAGBuilder
-
Constructor of DAGBuilder: it initializes everything.
- DAGBuilder(DAG<V, E>) - Constructor for class edu.snu.coral.common.dag.DAGBuilder
-
Constructor of DAGBuilder with a DAG to start from.
- DAGDirectory() - Constructor for class edu.snu.coral.conf.JobConf.DAGDirectory
-
- DataCommunicationPatternProperty - Class in edu.snu.coral.common.ir.edge.executionproperty
-
DataCommunicationPattern ExecutionProperty.
- DataCommunicationPatternProperty.Value - Enum in edu.snu.coral.common.ir.edge.executionproperty
-
Possible values of DataCommunicationPattern ExecutionProperty.
- DataFlowModelProperty - Class in edu.snu.coral.common.ir.edge.executionproperty
-
DataFlowModel ExecutionProperty.
- DataFlowModelProperty.Value - Enum in edu.snu.coral.common.ir.edge.executionproperty
-
Possible values of DataFlowModel ExecutionProperty.
- DataFrameReader - Class in edu.snu.coral.compiler.frontend.spark.sql
-
A data frame reader to create the initial dataset.
- Dataset<T> - Class in edu.snu.coral.compiler.frontend.spark.sql
-
A dataset component: it represents relational data.
- DataSkewCompositePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.composite
-
Pass to modify the DAG for a job to perform data skew.
- DataSkewCompositePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.DataSkewCompositePass
-
Default constructor.
- DataSkewEdgeDataStorePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Pass to annotate the DAG for a job to perform data skew.
- DataSkewEdgeDataStorePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewEdgeDataStorePass
-
Default constructor.
- DataSkewEdgeMetricCollectionPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Pass to annotate the DAG for a job to perform data skew.
- DataSkewEdgeMetricCollectionPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewEdgeMetricCollectionPass
-
Default constructor.
- DataSkewEdgePartitionerPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
- DataSkewEdgePartitionerPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewEdgePartitionerPass
-
Default constructor.
- DataSkewHashPartitioner - Class in edu.snu.coral.runtime.executor.data.partitioner
-
An implementation of
Partitioner
which hashes output data from a source task appropriate to detect data skew.
- DataSkewHashPartitioner(int) - Constructor for class edu.snu.coral.runtime.executor.data.partitioner.DataSkewHashPartitioner
-
- DataSkewPolicy - Class in edu.snu.coral.compiler.optimizer.policy
-
A policy to perform data skew dynamic optimization.
- DataSkewPolicy() - Constructor for class edu.snu.coral.compiler.optimizer.policy.DataSkewPolicy
-
Default constructor.
- DataSkewReshapingPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping
-
Pass to modify the DAG for a job to perform data skew.
- DataSkewReshapingPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.DataSkewReshapingPass
-
Default constructor.
- DataSkewRuntimePass - Class in edu.snu.coral.runtime.common.optimizer.pass.runtime
-
Dynamic optimization pass for handling data skew.
- DataSkewRuntimePass() - Constructor for class edu.snu.coral.runtime.common.optimizer.pass.runtime.DataSkewRuntimePass
-
Constructor.
- DataSkewVertexPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Pass to annotate the DAG for a job to perform data skew.
- DataSkewVertexPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DataSkewVertexPass
-
Default constructor.
- DataStoreProperty - Class in edu.snu.coral.common.ir.edge.executionproperty
-
DataStore ExecutionProperty.
- DataStoreProperty.Value - Enum in edu.snu.coral.common.ir.edge.executionproperty
-
Possible values of DataStore ExecutionProperty.
- DataTransfer - Class in edu.snu.coral.runtime.executor.datatransfer
-
- DataTransfer(String) - Constructor for class edu.snu.coral.runtime.executor.datatransfer.DataTransfer
-
- DataTransferFactory - Class in edu.snu.coral.runtime.executor.datatransfer
-
- DataTransferFactory(int, BlockManagerWorker) - Constructor for class edu.snu.coral.runtime.executor.datatransfer.DataTransferFactory
-
- DataUtil - Class in edu.snu.coral.runtime.executor.data
-
Utility methods for data handling (e.g., (de)serialization).
- DataUtil.InputStreamIterator<T> - Class in edu.snu.coral.runtime.executor.data
-
- decode(InputStream) - Method in class edu.snu.coral.common.coder.BytesCoder
-
- decode(InputStream) - Method in interface edu.snu.coral.common.coder.Coder
-
Decodes the a value from the given input stream.
- decode(InputStream) - Method in class edu.snu.coral.common.coder.Coder.DummyCoder
-
- decode(InputStream) - Method in class edu.snu.coral.compiler.frontend.beam.coder.BeamCoder
-
- decode(InputStream) - Method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
- decode(InputStream) - Method in class edu.snu.coral.compiler.frontend.spark.coder.SparkCoder
-
- DefaultEdgeUsedDataHandlingPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Pass for initiating IREdge UsedDataHandling ExecutionProperty with default values.
- DefaultEdgeUsedDataHandlingPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DefaultEdgeUsedDataHandlingPass
-
Default constructor.
- DefaultParallelismPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Optimization pass for tagging parallelism execution property.
- DefaultParallelismPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
-
Default constructor with desired number of source parallelism 1, shuffle decreasing factor 2.
- DefaultParallelismPass(int, int) - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DefaultParallelismPass
-
Default constructor.
- DefaultPolicy - Class in edu.snu.coral.compiler.optimizer.policy
-
A basic default policy, that performs the minimum amount of optimization to be done to a specific DAG.
- DefaultPolicy() - Constructor for class edu.snu.coral.compiler.optimizer.policy.DefaultPolicy
-
Default constructor.
- DefaultPolicyWithSeparatePass - Class in edu.snu.coral.compiler.optimizer.policy
-
A simple example policy to demonstrate a policy with a separate, refactored pass.
- DefaultPolicyWithSeparatePass() - Constructor for class edu.snu.coral.compiler.optimizer.policy.DefaultPolicyWithSeparatePass
-
Default constructor.
- DefaultPolicyWithSeparatePass.RefactoredPass - Class in edu.snu.coral.compiler.optimizer.policy
-
A simple custom pass consisted of the two passes at the end of the default pass.
- DefaultStagePartitioningPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Default method of partitioning an IR DAG into stages.
- DefaultStagePartitioningPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DefaultStagePartitioningPass
-
Default constructor.
- deleteFile() - Method in class edu.snu.coral.runtime.executor.data.block.FileBlock
-
Deletes the file that contains this block data.
- deleteMetadata() - Method in class edu.snu.coral.runtime.executor.data.metadata.FileMetadata
-
Deletes the metadata.
- deleteMetadata() - Method in class edu.snu.coral.runtime.executor.data.metadata.LocalFileMetadata
-
- deleteMetadata() - Method in class edu.snu.coral.runtime.executor.data.metadata.RemoteFileMetadata
-
- DeployMode() - Constructor for class edu.snu.coral.conf.JobConf.DeployMode
-
- dequeue() - Method in interface edu.snu.coral.runtime.master.scheduler.PendingTaskGroupQueue
-
Dequeues the next TaskGroup to be scheduled.
- dequeue() - Method in class edu.snu.coral.runtime.master.scheduler.SingleJobTaskGroupQueue
-
Dequeues the next TaskGroup to be scheduled according to job dependency priority.
- deriveSerializerFrom(SparkContext) - Static method in class edu.snu.coral.compiler.frontend.spark.core.java.SparkFrontendUtils
-
Derive Spark serializer from a spark context.
- deserializePartition(long, Coder, K, InputStream) - Static method in class edu.snu.coral.runtime.executor.data.DataUtil
-
Reads the data of a partition from an input stream and deserializes it.
- DirectByteArrayOutputStream - Class in edu.snu.coral.common
-
This class represents a custom implementation of
ByteArrayOutputStream
,
which enables to get bytes buffer directly (without memory copy).
- DirectByteArrayOutputStream() - Constructor for class edu.snu.coral.common.DirectByteArrayOutputStream
-
Default constructor.
- DirectByteArrayOutputStream(int) - Constructor for class edu.snu.coral.common.DirectByteArrayOutputStream
-
Constructor specifying the size.
- DisaggregationEdgeDataStorePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A pass to support Disaggregated Resources by tagging edges.
- DisaggregationEdgeDataStorePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.DisaggregationEdgeDataStorePass
-
Default constructor.
- DisaggregationPolicy - Class in edu.snu.coral.compiler.optimizer.policy
-
A policy to demonstrate the disaggregation optimization, that uses GlusterFS as file storage.
- DisaggregationPolicy() - Constructor for class edu.snu.coral.compiler.optimizer.policy.DisaggregationPolicy
-
Default constructor.
- distinct() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- distinct(int) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- DoTransform<I,O> - Class in edu.snu.coral.compiler.frontend.beam.transform
-
DoFn transform implementation.
- DoTransform(DoFn, PipelineOptions) - Constructor for class edu.snu.coral.compiler.frontend.beam.transform.DoTransform
-
DoTransform Constructor.
- DriverEndpoint - Class in edu.snu.coral.client
-
A request endpoint in driver side of a job.
- DriverEndpoint(JobStateManager, ClientEndpoint) - Constructor for class edu.snu.coral.client.DriverEndpoint
-
Construct an endpoint in driver side.
- DriverMemMb() - Constructor for class edu.snu.coral.conf.JobConf.DriverMemMb
-
- DriverStopHandler() - Constructor for class edu.snu.coral.driver.CoralDriver.DriverStopHandler
-
- DUMMY_CODER - Static variable in interface edu.snu.coral.common.coder.Coder
-
Dummy coder.
- DummyCoder() - Constructor for class edu.snu.coral.common.coder.Coder.DummyCoder
-
- dynamicOptimization(PhysicalPlan, MetricCollectionBarrierVertex) - Static method in class edu.snu.coral.runtime.common.optimizer.RuntimeOptimizer
-
Dynamic optimization method to process the dag with an appropriate pass, decided by the stats.
- DynamicOptimizationEvent - Class in edu.snu.coral.runtime.common.eventhandler
-
An event for triggering dynamic optimization.
- DynamicOptimizationEvent(PhysicalPlan, MetricCollectionBarrierVertex, Pair<String, String>) - Constructor for class edu.snu.coral.runtime.common.eventhandler.DynamicOptimizationEvent
-
Default constructor.
- DynamicOptimizationEventHandler - Class in edu.snu.coral.runtime.common.eventhandler
-
Class for handling event to perform dynamic optimization.
- DynamicOptimizationException - Exception in edu.snu.coral.common.exception
-
DynamicOptimizationException.
- DynamicOptimizationException(Throwable) - Constructor for exception edu.snu.coral.common.exception.DynamicOptimizationException
-
Constructor of DynamicOptimizationException.
- DynamicOptimizationException(String) - Constructor for exception edu.snu.coral.common.exception.DynamicOptimizationException
-
Constructor of DynamicOptimizationException.
- DynamicOptimizationProperty - Class in edu.snu.coral.common.ir.vertex.executionproperty
-
DynamicOptimizationType ExecutionProperty.
- DynamicOptimizationProperty.Value - Enum in edu.snu.coral.common.ir.vertex.executionproperty
-
Possible values of DynamicOptimization ExecutionProperty.
- FailedContextHandler() - Constructor for class edu.snu.coral.driver.CoralDriver.FailedContextHandler
-
- FailedEvaluatorHandler() - Constructor for class edu.snu.coral.driver.CoralDriver.FailedEvaluatorHandler
-
- FileArea - Class in edu.snu.coral.runtime.executor.data
-
A file area descriptor.
- FileArea(String, long, long) - Constructor for class edu.snu.coral.runtime.executor.data.FileArea
-
Creates a file area.
- FileBlock<K extends Serializable> - Class in edu.snu.coral.runtime.executor.data.block
-
This class represents a block which is stored in (local or remote) file.
- FileBlock(Coder, String, FileMetadata<K>) - Constructor for class edu.snu.coral.runtime.executor.data.block.FileBlock
-
Constructor.
- FileDirectory() - Constructor for class edu.snu.coral.conf.JobConf.FileDirectory
-
- FileMetadata<K extends Serializable> - Class in edu.snu.coral.runtime.executor.data.metadata
-
This class represents a metadata for a
Block
.
- FileMetadata() - Constructor for class edu.snu.coral.runtime.executor.data.metadata.FileMetadata
-
Construct a new file metadata.
- FileMetadata(List<PartitionMetadata<K>>) - Constructor for class edu.snu.coral.runtime.executor.data.metadata.FileMetadata
-
Construct a file metadata with existing partition metadata.
- FileStore - Interface in edu.snu.coral.runtime.executor.data.stores
-
Stores blocks in (local or remote) files.
- filter(Function<T, Boolean>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- filterVertices(Predicate<V>) - Method in class edu.snu.coral.common.dag.DAG
-
Filters the vertices according to the given condition.
- finishBundle(DoFn<KV<Integer, Pair<List<Integer>, List<Double>>>, KV<Integer, List<Double>>>.FinishBundleContext) - Method in class edu.snu.coral.examples.beam.AlternatingLeastSquare.CalculateNextMatrix
-
FinishBundle method for BEAM.
- finishBundle() - Method in class edu.snu.coral.examples.beam.MultinomialLogisticRegression.ApplyGradient
-
FinishBundle method for BEAM.
- finishBundle(DoFn<String, KV<Integer, List<Double>>>.FinishBundleContext) - Method in class edu.snu.coral.examples.beam.MultinomialLogisticRegression.CalculateGradient
-
FinishBundle method for BEAM.
- first() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- flatMap(FlatMapFunction<T, U>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- flatMapToPair(PairFlatMapFunction<T, K2, V2>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- FlatMapTransform<T,U> - Class in edu.snu.coral.compiler.frontend.spark.transform
-
Flatmap Transform that flattens each output element after mapping each elements to an iterator.
- FlatMapTransform(FlatMapFunction<T, U>) - Constructor for class edu.snu.coral.compiler.frontend.spark.transform.FlatMapTransform
-
Constructor.
- FlattenTransform<T> - Class in edu.snu.coral.compiler.frontend.beam.transform
-
Flatten transform implementation.
- FlattenTransform() - Constructor for class edu.snu.coral.compiler.frontend.beam.transform.FlattenTransform
-
FlattenTransform Constructor.
- flush() - Method in class edu.snu.coral.driver.RemoteClientMessageLoggingHandler
-
- fold(T, Function2<T, T, T>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- foreach(VoidFunction<T>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- foreachAsync(VoidFunction<T>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- foreachPartition(VoidFunction<Iterator<T>>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- foreachPartitionAsync(VoidFunction<Iterator<T>>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- forEachProperties(Consumer<? super ExecutionProperty>) - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
Same as forEach function in Java 8, but for execution properties.
- from(Dataset<U>) - Static method in class edu.snu.coral.compiler.frontend.spark.sql.Dataset
-
Using the immutable property of datasets, we can downcast spark datasets to our class using this function.
- from(SparkSession) - Static method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession
-
Method to downcast Spark's spark session to our spark session class.
- fromOptions(PipelineOptions) - Static method in class edu.snu.coral.compiler.frontend.beam.CoralPipelineRunner
-
Static initializer for creating PipelineRunner with the given options.
- generateBlockId(String, int) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Generates the ID for a block, whose data is the output of a task.
- generateExecutorId() - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Generates the ID for executor.
- generateLogicalTaskId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Generates the ID for
Task
.
- generateMessageId() - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Generates the ID for a control message.
- generatePhysicalPlanId() - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
- generatePhysicalTaskId(int, String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Generates the ID for
Task
.
- generateResourceSpecId() - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Generates the ID for a resource specification.
- generateRuntimeEdgeId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
- generateStageEdgeId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
- generateStageId(Integer) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Generates the ID for
Stage
.
- generateTaskGroupId(int, String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
- get(ExecutionProperty.Key) - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
Get the value of the given execution property type.
- getAncestors(String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the ancestors of a vertex.
- getAssignedLoopVertexOf(V) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the wrapping LoopVertex of the vertex.
- getAttemptCountForStage(String) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- getAttemptIdx() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getBlockId() - Method in exception edu.snu.coral.runtime.common.exception.AbsentBlockException
-
- getBlockId() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockInputStream
-
- getBlockId() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
- getBlockId() - Method in interface edu.snu.coral.runtime.executor.data.blocktransfer.BlockStream
-
Gets the block id.
- getBlockLocationFuture(String) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster
-
Returns a
CompletableFuture
of block location, which is not yet resolved in
SCHEDULED
state.
- getBlockMap() - Method in class edu.snu.coral.runtime.executor.data.stores.LocalBlockStore
-
- getBlockStore() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockInputStream
-
- getBlockStore() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
- getBlockStore() - Method in interface edu.snu.coral.runtime.executor.data.blocktransfer.BlockStream
-
Gets the block store type.
- getBufDirectly() - Method in class edu.snu.coral.common.DirectByteArrayOutputStream
-
- getBuilder() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getCapacity() - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification
-
- getChannelClass() - Method in class edu.snu.coral.runtime.common.NativeChannelImplementationSelector
-
- getChannelClass() - Method in interface edu.snu.coral.runtime.common.NettyChannelImplementationSelector
-
- getChannelClass() - Method in class edu.snu.coral.runtime.common.NioChannelImplementationSelector
-
- getCheckpointFile() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- getChildren(String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the children vertices of the given vertex.
- getClone() - Method in class edu.snu.coral.common.ir.vertex.InitializedSourceVertex
-
- getClone() - Method in class edu.snu.coral.common.ir.vertex.IRVertex
-
- getClone() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getClone() - Method in class edu.snu.coral.common.ir.vertex.MetricCollectionBarrierVertex
-
- getClone() - Method in class edu.snu.coral.common.ir.vertex.OperatorVertex
-
- getClone() - Method in class edu.snu.coral.compiler.frontend.beam.source.BeamBoundedSourceVertex
-
- getClone() - Method in class edu.snu.coral.compiler.frontend.spark.source.SparkBoundedSourceVertex
-
- getClone() - Method in class edu.snu.coral.compiler.optimizer.examples.EmptyComponents.EmptySourceVertex
-
- getCoder() - Method in class edu.snu.coral.common.ir.edge.IREdge
-
- getCoder() - Method in class edu.snu.coral.runtime.common.plan.RuntimeEdge
-
- getCoder(String) - Method in class edu.snu.coral.runtime.executor.data.CoderManager
-
Return the coder for the specified runtime edge.
- getCoderArguments() - Method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
- getCoderFromWorker(String) - Method in class edu.snu.coral.runtime.executor.data.stores.AbstractBlockStore
-
- getCompileTimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DataSkewPolicy
-
- getCompileTimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DefaultPolicy
-
- getCompileTimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DefaultPolicyWithSeparatePass
-
- getCompileTimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DisaggregationPolicy
-
- getCompileTimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.PadoPolicy
-
- getCompileTimePasses() - Method in interface edu.snu.coral.compiler.optimizer.policy.Policy
-
- getCompileTimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.SailfishPolicy
-
- getCompleteFuture() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockInputStream
-
- getCompleteTaskGroups() - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- getComputationUnitId() - Method in class edu.snu.coral.runtime.common.metric.MetricData
-
- getComputationUnitId() - Method in class edu.snu.coral.runtime.common.metric.MetricDataBuilder
-
- getContainerType() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStage
-
- getContainerType() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getContainerType() - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- getContainerType() - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification
-
- getCount() - Method in class edu.snu.coral.common.DirectByteArrayOutputStream
-
- getCount() - Method in class edu.snu.coral.runtime.executor.data.FileArea
-
- getCurrentState() - Method in class edu.snu.coral.common.StateMachine
-
- getCurrentTaskGroupExecutionState() - Method in class edu.snu.coral.runtime.executor.TaskGroupStateManager
-
- getDAG() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getDagIncomingEdges() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getDagOutgoingEdges() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getDAGSnapshot() - Method in class edu.snu.coral.common.ir.vertex.MetricCollectionBarrierVertex
-
Access the DAG snapshot when triggering dynamic optimization.
- getData() - Method in class edu.snu.coral.runtime.executor.data.NonSerializedPartition
-
- getData() - Method in interface edu.snu.coral.runtime.executor.data.Partition
-
- getData() - Method in class edu.snu.coral.runtime.executor.data.SerializedPartition
-
- getDeployModeConf(Configuration) - Static method in class edu.snu.coral.client.JobLauncher
-
Get deploy mode configuration.
- getDescendants(String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the descendants of a vertex.
- getDst() - Method in class edu.snu.coral.common.dag.Edge
-
- getDstVertex() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStageEdge
-
- getDstVertex() - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdge
-
- getEdgeBetween(String, String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the edge between two vertices.
- getEdgeWithLoop(IREdge) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getElementsTotal() - Method in class edu.snu.coral.runtime.executor.data.metadata.PartitionMetadata
-
- getElementsTotal() - Method in class edu.snu.coral.runtime.executor.data.SerializedPartition
-
- getEndTime() - Method in class edu.snu.coral.runtime.common.metric.MetricDataBuilder
-
- getEventClass() - Method in interface edu.snu.coral.common.eventhandler.CommonEventHandler
-
fetches the class of the event.
- getEventClass() - Method in class edu.snu.coral.runtime.common.eventhandler.DynamicOptimizationEventHandler
-
- getEventClass() - Method in class edu.snu.coral.runtime.master.eventhandler.UpdatePhysicalPlanEventHandler
-
- getEventHandlers() - Method in class edu.snu.coral.runtime.common.optimizer.pass.runtime.DataSkewRuntimePass
-
- getEventHandlers() - Method in interface edu.snu.coral.runtime.common.optimizer.pass.runtime.RuntimePass
-
- getExecutionProperties() - Method in class edu.snu.coral.common.ir.edge.IREdge
-
- getExecutionProperties() - Method in class edu.snu.coral.common.ir.vertex.IRVertex
-
- getExecutionProperties() - Method in class edu.snu.coral.runtime.common.plan.RuntimeEdge
-
- getExecutionPropertyToModify() - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.AnnotatingPass
-
Getter for key of execution property to modify.
- getExecutorCapacity() - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- getExecutorId() - Method in class edu.snu.coral.runtime.executor.Executor
-
- getExecutorId() - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- getExecutorRepresenterMap() - Method in class edu.snu.coral.runtime.master.resource.ContainerManager
-
- getExecutorResourceConf(Configuration) - Static method in class edu.snu.coral.client.JobLauncher
-
Get executor resource configuration.
- getFailedExecutorRepresenterMap() - Method in class edu.snu.coral.runtime.master.resource.ContainerManager
-
- getFileAreas(String, KeyRange) - Method in interface edu.snu.coral.runtime.executor.data.stores.FileStore
-
Gets the list of
FileArea
s for the specified block.
- getFileAreas(String, KeyRange) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
- getFileAreas(String, KeyRange) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalFileStore
-
- getId() - Method in class edu.snu.coral.common.dag.Edge
-
- getId() - Method in class edu.snu.coral.common.dag.Vertex
-
- getId() - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
ID of the item this ExecutionPropertyMap class is keeping track of.
- getId() - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageEnvironment
-
- getId() - Method in class edu.snu.coral.runtime.common.message.ncs.NcsMessageEnvironment
-
- getId() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalPlan
-
- getId() - Method in class edu.snu.coral.runtime.executor.datatransfer.DataTransfer
-
- getIdToStageStates() - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- getIdToTaskGroupStates() - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- getIncomingEdgesOf(V) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the incoming edges of the given vertex.
- getIncomingEdgesOf(String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the incoming edges of the given vertex.
- getIndexFromTaskGroupId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Extracts task group index from a task group ID.
- getIrVertexId() - Method in class edu.snu.coral.runtime.common.plan.physical.Task
-
- getIRVertexOf(Task) - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalPlan
-
Get an IR vertex of the given task.
- getIterativeIncomingEdges() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getJobConf(String[]) - Static method in class edu.snu.coral.client.JobLauncher
-
Get job configuration.
- getJobId() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getJobId() - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- getJobState() - Method in class edu.snu.coral.client.ClientEndpoint
-
Get the current state of the running job.
- getJobState() - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- getKey() - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionProperty
-
- getKey() - Method in class edu.snu.coral.runtime.executor.data.metadata.PartitionMetadata
-
- getKey() - Method in class edu.snu.coral.runtime.executor.data.NonSerializedPartition
-
- getKey() - Method in interface edu.snu.coral.runtime.executor.data.Partition
-
- getKey() - Method in class edu.snu.coral.runtime.executor.data.SerializedPartition
-
- getKeyRange() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockInputStream
-
- getKeyRange() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
- getKeyRange() - Method in interface edu.snu.coral.runtime.executor.data.blocktransfer.BlockStream
-
Gets the key range.
- getLength() - Method in class edu.snu.coral.runtime.executor.data.SerializedPartition
-
- getLogicalTaskIdIdFromPhysicalTaskId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Extracts logical task ID from a physical task ID.
- getLoopFusionPass() - Static method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations
-
- getLoopInvariantCodeMotionPass() - Static method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.LoopOptimizations
-
- getLoopStackDepthOf(V) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the stack depth of the given vertex.
- getMaxNumberOfIterations() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getMemory() - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification
-
- getMessageSender(String) - Method in class edu.snu.coral.runtime.common.message.PersistentConnectionToMasterMap
-
Get the message sender corresponding to the given listener ID.
- getMetricByKey(String) - Method in class edu.snu.coral.runtime.master.MetricManagerMaster
-
- getMetricByKey(String) - Method in interface edu.snu.coral.runtime.master.MetricMessageHandler
-
Retrieves the string form of metric given the metric key.
- getMetricCollectionBarrierVertex() - Method in class edu.snu.coral.runtime.common.eventhandler.DynamicOptimizationEvent
-
- getMetricData() - Method in class edu.snu.coral.common.ir.vertex.MetricCollectionBarrierVertex
-
Method for retrieving metrics from the vertex.
- getMetrics() - Method in class edu.snu.coral.runtime.common.metric.MetricData
-
- getMetrics() - Method in class edu.snu.coral.runtime.common.metric.MetricDataBuilder
-
- getName() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getNewPhysicalPlan() - Method in class edu.snu.coral.runtime.common.eventhandler.UpdatePhysicalPlanEvent
-
- getNonIterativeIncomingEdges() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getNumericId() - Method in class edu.snu.coral.common.dag.Edge
-
- getNumericId() - Method in class edu.snu.coral.common.dag.Vertex
-
- getNumPartitions() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- getOffset() - Method in class edu.snu.coral.runtime.executor.data.metadata.PartitionMetadata
-
- getOrCreate() - Method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession.Builder
-
- getOutgoingEdgesOf(V) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the outgoing edges of the given vertex.
- getOutgoingEdgesOf(String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the outgoing edges of the given vertex.
- getParents(String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the parent vertices of the given vertex.
- getPartitionMetadataIterable() - Method in class edu.snu.coral.runtime.executor.data.metadata.FileMetadata
-
Gets a iterable containing the partition metadata of corresponding block.
- getPartitions() - Method in class edu.snu.coral.compiler.frontend.spark.core.RDD
-
- getPartitions(KeyRange<K>) - Method in interface edu.snu.coral.runtime.executor.data.block.Block
-
- getPartitions(KeyRange) - Method in class edu.snu.coral.runtime.executor.data.block.FileBlock
-
Retrieves the partitions of this block from the file in a specific key range and deserializes it.
- getPartitions(KeyRange) - Method in class edu.snu.coral.runtime.executor.data.block.NonSerializedMemoryBlock
-
- getPartitions(KeyRange) - Method in class edu.snu.coral.runtime.executor.data.block.SerializedMemoryBlock
-
- getPartitions(String, KeyRange<K>) - Method in interface edu.snu.coral.runtime.executor.data.stores.BlockStore
-
- getPartitions(String, KeyRange<K>) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
- getPartitions(String, KeyRange<K>) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalBlockStore
-
- getPartitionSize() - Method in class edu.snu.coral.runtime.executor.data.metadata.PartitionMetadata
-
- getPassList() - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.CompositePass
-
Getter for list of compile time passes.
- getPath() - Method in class edu.snu.coral.runtime.executor.data.FileArea
-
- getPhysicalPlan() - Method in class edu.snu.coral.runtime.common.eventhandler.DynamicOptimizationEvent
-
- getPosition() - Method in class edu.snu.coral.runtime.executor.data.FileArea
-
- getPrerequisiteExecutionProperties() - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.AnnotatingPass
-
- getPrerequisiteExecutionProperties() - Method in interface edu.snu.coral.compiler.optimizer.pass.compiletime.CompileTimePass
-
Getter for prerequisite execution properties.
- getPrerequisiteExecutionProperties() - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.CompositePass
-
- getPrerequisiteExecutionProperties() - Method in class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.ReshapingPass
-
- getProducerTaskGroupIds(String) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster
-
Gets the ids of the task groups which already produced or will produce data for a specific block.
- getProperty(ExecutionProperty.Key) - Method in class edu.snu.coral.common.ir.edge.IREdge
-
Get the executionProperty of the IREdge.
- getProperty(ExecutionProperty.Key) - Method in class edu.snu.coral.common.ir.vertex.IRVertex
-
Get the executionProperty of the IRVertex.
- getProperty(ExecutionProperty.Key) - Method in class edu.snu.coral.runtime.common.plan.RuntimeEdge
-
Get the execution property of the Runtime Edge.
- getPubSubEventHandler() - Method in class edu.snu.coral.common.eventhandler.PubSubEventHandlerWrapper
-
- getReadable(int) - Method in class edu.snu.coral.runtime.common.plan.physical.BoundedSourceTask
-
- getReadables() - Method in interface edu.snu.coral.common.ir.ReadablesWrapper
-
- getReadableWrapper(int) - Method in class edu.snu.coral.common.ir.vertex.InitializedSourceVertex
-
- getReadableWrapper(int) - Method in class edu.snu.coral.common.ir.vertex.SourceVertex
-
Gets parallel readable wrapper.
- getReadableWrapper(int) - Method in class edu.snu.coral.compiler.frontend.beam.source.BeamBoundedSourceVertex
-
- getReadableWrapper(int) - Method in class edu.snu.coral.compiler.frontend.spark.source.SparkBoundedSourceVertex
-
- getReadableWrapper(int) - Method in class edu.snu.coral.compiler.optimizer.examples.EmptyComponents.EmptySourceVertex
-
- getRemoteExecutorId() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockInputStream
-
- getRemoteExecutorId() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
- getRemoteExecutorId() - Method in interface edu.snu.coral.runtime.executor.data.blocktransfer.BlockStream
-
Gets the id of the remote executor.
- getResourceSpecId() - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification
-
- getResultId() - Static method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
This method is to be removed after a result handler is implemented.
- getRootVertices() - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the root vertices of this DAG.
- getRunningTaskGroups() - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- getRuntimeEdge() - Method in class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
- getRuntimeEdgeId() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockInputStream
-
- getRuntimeEdgeId() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
- getRuntimeEdgeId() - Method in interface edu.snu.coral.runtime.executor.data.blocktransfer.BlockStream
-
Gets the runtime edge id.
- getRuntimeEdgeIdFromBlockId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Extracts runtime edge ID from a block ID.
- getRuntimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DataSkewPolicy
-
- getRuntimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DefaultPolicy
-
- getRuntimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DefaultPolicyWithSeparatePass
-
- getRuntimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.DisaggregationPolicy
-
- getRuntimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.PadoPolicy
-
- getRuntimePasses() - Method in interface edu.snu.coral.compiler.optimizer.policy.Policy
-
- getRuntimePasses() - Method in class edu.snu.coral.compiler.optimizer.policy.SailfishPolicy
-
- getScheduleGroupIndex() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStage
-
- getScheduleGroupIndex() - Method in class edu.snu.coral.runtime.common.plan.stage.Stage
-
- getScheduleTimeoutMs() - Method in class edu.snu.coral.runtime.master.scheduler.RoundRobinSchedulingPolicy
-
- getScheduleTimeoutMs() - Method in interface edu.snu.coral.runtime.master.scheduler.SchedulingPolicy
-
Returns this scheduling policy's timeout before an executor assignment.
- getSerializedPartitions(KeyRange<K>) - Method in interface edu.snu.coral.runtime.executor.data.block.Block
-
- getSerializedPartitions(KeyRange) - Method in class edu.snu.coral.runtime.executor.data.block.FileBlock
-
- getSerializedPartitions(KeyRange) - Method in class edu.snu.coral.runtime.executor.data.block.NonSerializedMemoryBlock
-
- getSerializedPartitions(KeyRange) - Method in class edu.snu.coral.runtime.executor.data.block.SerializedMemoryBlock
-
- getSerializedPartitions(String, KeyRange<K>) - Method in interface edu.snu.coral.runtime.executor.data.stores.BlockStore
-
- getSerializedPartitions(String, KeyRange<K>) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
- getSerializedPartitions(String, KeyRange<K>) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalBlockStore
-
- getSerializedTaskGroupDag() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStage
-
- getSerializedTaskGroupDag() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getServerChannelClass() - Method in class edu.snu.coral.runtime.common.NativeChannelImplementationSelector
-
- getServerChannelClass() - Method in interface edu.snu.coral.runtime.common.NettyChannelImplementationSelector
-
- getServerChannelClass() - Method in class edu.snu.coral.runtime.common.NioChannelImplementationSelector
-
- getSideInput() - Method in class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
- getSideInputs() - Method in class edu.snu.coral.common.ContextImpl
-
- getSideInputs() - Method in interface edu.snu.coral.common.ir.vertex.transform.Transform.Context
-
- getSourceParallelism() - Method in class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
Get the parallelism of the source task.
- getSparkContext() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaPairRDD
-
- getSparkContext() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- getSrc() - Method in class edu.snu.coral.common.dag.Edge
-
- getSrcIrVertexId() - Method in class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
- getSrcVertex() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStageEdge
-
- getSrcVertex() - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdge
-
- getStageDAG() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalPlan
-
- getStageIdFromTaskGroupId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Extracts stage ID from a task group ID.
- getStageInternalDAG() - Method in class edu.snu.coral.runtime.common.plan.stage.Stage
-
- getStageState(String) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- getStartTime() - Method in class edu.snu.coral.runtime.common.metric.MetricDataBuilder
-
- getState() - Method in class edu.snu.coral.compiler.frontend.beam.CoralPipelineResult
-
- getState() - Method in exception edu.snu.coral.runtime.common.exception.AbsentBlockException
-
- getStateMachine() - Method in class edu.snu.coral.runtime.common.state.BlockState
-
- getStateMachine() - Method in class edu.snu.coral.runtime.common.state.JobState
-
- getStateMachine() - Method in class edu.snu.coral.runtime.common.state.StageState
-
- getStateMachine() - Method in class edu.snu.coral.runtime.common.state.TaskGroupState
-
- getStateMachine() - Method in class edu.snu.coral.runtime.common.state.TaskState
-
- getStorageLevel() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- getTag() - Method in class edu.snu.coral.compiler.frontend.beam.transform.CreateViewTransform
-
get the Tag of the Transform.
- getTaskGroupDag() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStage
-
- getTaskGroupId() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getTaskGroupIds() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStage
-
- getTaskGroupIdx() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getTaskGroupIdxToKeyRange() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStageEdge
-
- getTaskGroupIncomingEdges() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getTaskGroupOutgoingEdges() - Method in class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
- getTaskGroupState(String) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
- getTaskIndexFromBlockId(String) - Static method in class edu.snu.coral.runtime.common.RuntimeIdGenerator
-
Extracts task index from a block ID.
- getTaskInfo() - Method in class edu.snu.coral.runtime.common.eventhandler.DynamicOptimizationEvent
-
- getTaskInfo() - Method in class edu.snu.coral.runtime.common.eventhandler.UpdatePhysicalPlanEvent
-
- getTaskIRVertexMap() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalPlan
-
- getTaskIRVertexMap() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalPlanGenerator
-
Getter for taskIRVertexMap.
- getTerminationCondition() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- getTopologicalSort() - Method in class edu.snu.coral.common.dag.DAG
-
Gets the DAG's vertices in topologically sorted order.
- getTransform() - Method in class edu.snu.coral.common.ir.vertex.OperatorVertex
-
- getTransform() - Method in class edu.snu.coral.runtime.common.plan.physical.OperatorTask
-
- getValue() - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionProperty
-
- getVertexById(String) - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the vertex given its ID.
- getVertices() - Method in class edu.snu.coral.common.dag.DAG
-
Retrieves the vertices of this DAG.
- glom() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- GLUSTER_DISK_DIRECTORY - Static variable in class edu.snu.coral.conf.JobConf
-
- GlusterFileStore - Class in edu.snu.coral.runtime.executor.data.stores
-
Stores blocks in a mounted GlusterFS volume.
- GlusterVolumeDirectory() - Constructor for class edu.snu.coral.conf.JobConf.GlusterVolumeDirectory
-
- groupBy(Function<T, U>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- groupBy(Function<T, U>, int) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- GroupByKeyTransform<I> - Class in edu.snu.coral.compiler.frontend.beam.transform
-
Group Beam KVs.
- GroupByKeyTransform() - Constructor for class edu.snu.coral.compiler.frontend.beam.transform.GroupByKeyTransform
-
GroupByKey constructor.
- GroupByKeyTransform<K,V> - Class in edu.snu.coral.compiler.frontend.spark.transform
-
Transform for group by key transformation.
- GroupByKeyTransform() - Constructor for class edu.snu.coral.compiler.frontend.spark.transform.GroupByKeyTransform
-
Constructor.
- GrpcMessageEnvironment - Class in edu.snu.coral.runtime.common.message.grpc
-
This class is installed when every node, containing both driver and evaluator, has been started, and setup
grpc environment to implement RPC semantics defined in
edu.snu.coral.runtime.common.message
package.
- id() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- IdManager - Class in edu.snu.coral.common.ir
-
ID manager.
- IllegalEdgeOperationException - Exception in edu.snu.coral.common.exception
-
IllegalEdgeOperationException.
- IllegalEdgeOperationException(Throwable) - Constructor for exception edu.snu.coral.common.exception.IllegalEdgeOperationException
-
IllegalEdgeOperationException.
- IllegalMessageException - Exception in edu.snu.coral.common.exception
-
IllegalMessageException.
- IllegalMessageException(Throwable) - Constructor for exception edu.snu.coral.common.exception.IllegalMessageException
-
IllegalMessageException.
- IllegalStateTransitionException - Exception in edu.snu.coral.common.exception
-
IllegalStateTransitionException.
- IllegalStateTransitionException(Throwable) - Constructor for exception edu.snu.coral.common.exception.IllegalStateTransitionException
-
IllegalStateTransitionException.
- IllegalVertexOperationException - Exception in edu.snu.coral.common.exception
-
IllegalVertexOperationException.
- IllegalVertexOperationException(String) - Constructor for exception edu.snu.coral.common.exception.IllegalVertexOperationException
-
IllegalVertexOperationException.
- includes(Integer) - Method in class edu.snu.coral.runtime.common.data.HashRange
-
- includes(K) - Method in interface edu.snu.coral.runtime.common.data.KeyRange
-
- increaseMaxNumberOfIterations() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
increase the value of maximum number of iterations by 1.
- InitializedSourceVertex<T> - Class in edu.snu.coral.common.ir.vertex
-
Source vertex with initial data as object.
- InitializedSourceVertex(Iterable<T>) - Constructor for class edu.snu.coral.common.ir.vertex.InitializedSourceVertex
-
Constructor.
- initializeState(String, String) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster
-
Initializes the states of a block which will be produced by producer task(s).
- initiatePull(String, boolean, DataStoreProperty.Value, String, String, KeyRange) - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockTransfer
-
Initiate a pull-based block transfer.
- initiatePush(String, boolean, String, String, KeyRange) - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockTransfer
-
Initiate a push-based block transfer.
- InputReader - Class in edu.snu.coral.runtime.executor.datatransfer
-
Represents the input data transfer to a task.
- InputReader(int, IRVertex, RuntimeEdge, BlockManagerWorker) - Constructor for class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
- InputStreamIterator(InputStream, Coder<T>) - Constructor for class edu.snu.coral.runtime.executor.data.DataUtil.InputStreamIterator
-
- InputStreamIterator(InputStream, Coder<T>, long) - Constructor for class edu.snu.coral.runtime.executor.data.DataUtil.InputStreamIterator
-
- IntactPartitioner - Class in edu.snu.coral.runtime.executor.data.partitioner
-
An implementation of
Partitioner
which makes an output data
from a source task to a single
Partition
.
- IntactPartitioner() - Constructor for class edu.snu.coral.runtime.executor.data.partitioner.IntactPartitioner
-
- InvalidParameterException - Exception in edu.snu.coral.common.exception
-
InvalidParameterException.
- InvalidParameterException(String) - Constructor for exception edu.snu.coral.common.exception.InvalidParameterException
-
InvalidParameterException.
- IORequestHandleThreadsTotal() - Constructor for class edu.snu.coral.conf.JobConf.IORequestHandleThreadsTotal
-
- IREdge - Class in edu.snu.coral.common.ir.edge
-
Physical execution plan of intermediate data movement.
- IREdge(DataCommunicationPatternProperty.Value, IRVertex, IRVertex, Coder) - Constructor for class edu.snu.coral.common.ir.edge.IREdge
-
Constructor of IREdge.
- IREdge(DataCommunicationPatternProperty.Value, IRVertex, IRVertex, Coder, Boolean) - Constructor for class edu.snu.coral.common.ir.edge.IREdge
-
Constructor of IREdge.
- IRVertex - Class in edu.snu.coral.common.ir.vertex
-
The top-most wrapper for a user operation in the IR.
- IRVertex() - Constructor for class edu.snu.coral.common.ir.vertex.IRVertex
-
Constructor of IRVertex.
- irVertexPropertiesToString() - Method in class edu.snu.coral.common.ir.vertex.IRVertex
-
- isAll() - Method in class edu.snu.coral.runtime.common.data.HashRange
-
- isAll() - Method in interface edu.snu.coral.runtime.common.data.KeyRange
-
- isCheckpointed() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- isCompositeVertex(V) - Method in class edu.snu.coral.common.dag.DAG
-
Checks whether the given vertex is assigned with a wrapping LoopVertex.
- isEmpty() - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Checks whether the DAGBuilder is empty.
- isEmpty() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- isEmpty() - Method in class edu.snu.coral.runtime.common.plan.stage.StageBuilder
-
- isEmpty() - Method in interface edu.snu.coral.runtime.master.scheduler.PendingTaskGroupQueue
-
Checks whether there are schedulable TaskGroups in the queue or not.
- isEmpty() - Method in class edu.snu.coral.runtime.master.scheduler.SingleJobTaskGroupQueue
-
- isEncodePartialBlockEnabled() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockInputStream
-
- isEncodePartialBlockEnabled() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.BlockOutputStream
-
- isEncodePartialBlockEnabled() - Method in interface edu.snu.coral.runtime.executor.data.blocktransfer.BlockStream
-
Gets whether the sender should start encoding even though the whole block has not been written yet.
- isRegisterByteSizeObserverCheap(Pair<A, B>) - Method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
Returns whether both leftCoder and rightCoder are considered not expensive.
- isSerialized() - Method in class edu.snu.coral.runtime.executor.data.NonSerializedPartition
-
- isSerialized() - Method in interface edu.snu.coral.runtime.executor.data.Partition
-
- isSerialized() - Method in class edu.snu.coral.runtime.executor.data.SerializedPartition
-
- isSideInput() - Method in class edu.snu.coral.common.ir.edge.IREdge
-
- isSideInput() - Method in class edu.snu.coral.runtime.common.plan.RuntimeEdge
-
- isSideInputReader() - Method in class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
- iterator(Partition, TaskContext) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- JavaPairRDD<K,V> - Class in edu.snu.coral.compiler.frontend.spark.core.java
-
Java RDD for pairs.
- JavaRDD<T> - Class in edu.snu.coral.compiler.frontend.spark.core.java
-
Java RDD.
- javaRDD() - Method in class edu.snu.coral.compiler.frontend.spark.sql.Dataset
-
Create a javaRDD component from this data set.
- JavaSparkContext - Class in edu.snu.coral.compiler.frontend.spark.core.java
-
Spark context wrapper for Java.
- JavaSparkContext(SparkContext) - Constructor for class edu.snu.coral.compiler.frontend.spark.core.java.JavaSparkContext
-
Constructor.
- JavaSparkPi - Class in edu.snu.coral.examples.spark
-
Computes an approximation to pi.
- JavaWordCount - Class in edu.snu.coral.examples.spark
-
Java Wordcount example.
- JOB_ID - Static variable in class edu.snu.coral.conf.JobConf
-
- JobConf - Class in edu.snu.coral.conf
-
Job Configurations.
- JobConf() - Constructor for class edu.snu.coral.conf.JobConf
-
- JobConf.DAGDirectory - Class in edu.snu.coral.conf
-
Directory to store JSON representation of intermediate DAGs.
- JobConf.DeployMode - Class in edu.snu.coral.conf
-
Deploy mode.
- JobConf.DriverMemMb - Class in edu.snu.coral.conf
-
Coral driver memory.
- JobConf.ExecutorCapacity - Class in edu.snu.coral.conf
-
Executor capacity.
- JobConf.ExecutorId - Class in edu.snu.coral.conf
-
Executor id.
- JobConf.ExecutorJsonContents - Class in edu.snu.coral.conf
-
Contents of the JSON file that specifies resource layout.
- JobConf.ExecutorJsonPath - Class in edu.snu.coral.conf
-
Path to the JSON file that specifies resource layout.
- JobConf.FileDirectory - Class in edu.snu.coral.conf
-
Directory to store files for storing blocks.
- JobConf.GlusterVolumeDirectory - Class in edu.snu.coral.conf
-
Directory points the mounted GlusterFS volume to store files in remote fashion.
- JobConf.HashRangeMultiplier - Class in edu.snu.coral.conf
-
Hash range multiplier.
- JobConf.IORequestHandleThreadsTotal - Class in edu.snu.coral.conf
-
Number of I/O threads for block fetch requests from other executor.
- JobConf.JobId - Class in edu.snu.coral.conf
-
Job id.
- JobConf.JVMHeapSlack - Class in edu.snu.coral.conf
-
The fraction of container memory not to use fo the JVM heap.
- JobConf.MaxScheduleAttempt - Class in edu.snu.coral.conf
-
Max number of attempts for task group scheduling.
- JobConf.OptimizationPolicy - Class in edu.snu.coral.conf
-
The name of the optimization policy.
- JobConf.PartitionTransportClientNumThreads - Class in edu.snu.coral.conf
-
The number of threads of block transfer client.
- JobConf.PartitionTransportServerBacklog - Class in edu.snu.coral.conf
-
The maximum length which the pending connection queue of block transfer may grow to.
- JobConf.PartitionTransportServerNumListeningThreads - Class in edu.snu.coral.conf
-
The number of listening threads of block transfer server.
- JobConf.PartitionTransportServerNumWorkingThreads - Class in edu.snu.coral.conf
-
The number of block transfer server threads
which work on accepted connections.
- JobConf.PartitionTransportServerPort - Class in edu.snu.coral.conf
-
The TCP port to which local block transfer binds.
- JobConf.SchedulerTimeoutMs - Class in edu.snu.coral.conf
-
Scheduler timeout in ms.
- JobConf.ScheduleSerThread - Class in edu.snu.coral.conf
-
The number of serialization threads for scheduling.
- JobConf.SerializedDAG - Class in edu.snu.coral.conf
-
Serialized {edu.snu.coral.common.dag.DAG} from user main method.
- JobConf.UserMainArguments - Class in edu.snu.coral.conf
-
User Main Arguments.
- JobConf.UserMainClass - Class in edu.snu.coral.conf
-
User Main Class Name.
- JobId() - Constructor for class edu.snu.coral.conf.JobConf.JobId
-
- JobLauncher - Class in edu.snu.coral.client
-
Job launcher.
- JobMessageHandler() - Constructor for class edu.snu.coral.client.CoralClient.JobMessageHandler
-
- JobState - Class in edu.snu.coral.runtime.common.state
-
Represents the states and their transitions of a
PhysicalPlan
.
- JobState() - Constructor for class edu.snu.coral.runtime.common.state.JobState
-
- JobState.State - Enum in edu.snu.coral.runtime.common.state
-
JobState.
- JobStateManager - Class in edu.snu.coral.runtime.master
-
Manages the states related to a job.
- JobStateManager(PhysicalPlan, BlockManagerMaster, MetricMessageHandler, int) - Constructor for class edu.snu.coral.runtime.master.JobStateManager
-
- JsonParseException - Exception in edu.snu.coral.common.exception
-
JsonParseException.
- JsonParseException(Throwable) - Constructor for exception edu.snu.coral.common.exception.JsonParseException
-
JsonParseException.
- JVMHeapSlack() - Constructor for class edu.snu.coral.conf.JobConf.JVMHeapSlack
-
- main(String[]) - Static method in class edu.snu.coral.client.JobLauncher
-
Main JobLauncher method.
- main(String[]) - Static method in class edu.snu.coral.compiler.optimizer.examples.MapReduceDisaggregationOptimization
-
Main function of the example MR program.
- main(String[]) - Static method in class edu.snu.coral.examples.beam.AlternatingLeastSquare
-
Main function for the ALS BEAM program.
- main(String[]) - Static method in class edu.snu.coral.examples.beam.AlternatingLeastSquareInefficient
-
Main function for the ALS BEAM program.
- main(String[]) - Static method in class edu.snu.coral.examples.beam.Broadcast
-
Main function for the BEAM program.
- main(String[]) - Static method in class edu.snu.coral.examples.beam.MapReduce
-
Main function for the MR BEAM program.
- main(String[]) - Static method in class edu.snu.coral.examples.beam.MultinomialLogisticRegression
-
Main function for the MLR BEAM program.
- main(String[]) - Static method in class edu.snu.coral.examples.spark.JavaSparkPi
-
Main method.
- main(String[]) - Static method in class edu.snu.coral.examples.spark.JavaWordCount
-
Main method.
- map(Function<T, O>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
Map transform.
- mapEdgeWithLoop(IREdge, IREdge) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Maps an edge from/to loop with the corresponding edge from/to internal vertex.
- mapPartitions(FlatMapFunction<Iterator<T>, U>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- mapPartitions(FlatMapFunction<Iterator<T>, U>, boolean) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- mapPartitionsToPair(PairFlatMapFunction<Iterator<T>, K2, V2>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- mapPartitionsToPair(PairFlatMapFunction<Iterator<T>, K2, V2>, boolean) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- mapPartitionsWithIndex(Function2<Integer, Iterator<T>, Iterator<R>>, boolean) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- MapReduce - Class in edu.snu.coral.examples.beam
-
Sample MapReduce application.
- MapReduceDisaggregationOptimization - Class in edu.snu.coral.compiler.optimizer.examples
-
A sample MapReduceDisaggregationOptimization application.
- mapToPair(PairFunction<T, K2, V2>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- MapToPairTransform<T,K,V> - Class in edu.snu.coral.compiler.frontend.spark.transform
-
Map elements to Pair elements.
- MapToPairTransform(PairFunction<T, K, V>) - Constructor for class edu.snu.coral.compiler.frontend.spark.transform.MapToPairTransform
-
Constructor.
- MapTransform<I,O> - Class in edu.snu.coral.compiler.frontend.spark.transform
-
Map Transform for Spark.
- MapTransform(Function<I, O>) - Constructor for class edu.snu.coral.compiler.frontend.spark.transform.MapTransform
-
Constructor.
- master(String) - Method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession.Builder
-
- MASTER_COMMUNICATION_ID - Static variable in interface edu.snu.coral.runtime.common.message.MessageEnvironment
-
- MasterControlMessageReceiver() - Constructor for class edu.snu.coral.runtime.master.RuntimeMaster.MasterControlMessageReceiver
-
- max(Comparator<T>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- MaxScheduleAttempt() - Constructor for class edu.snu.coral.conf.JobConf.MaxScheduleAttempt
-
- MemoryStore - Class in edu.snu.coral.runtime.executor.data.stores
-
Store data in local memory.
- mergeAccumulators(Iterable<List<Pair<List<Integer>, List<Double>>>>) - Method in class edu.snu.coral.examples.beam.AlternatingLeastSquare.TrainingDataCombiner
-
- MessageContext - Interface in edu.snu.coral.runtime.common.message
-
- MessageEnvironment - Interface in edu.snu.coral.runtime.common.message
-
Set up
MessageListener
s to handle incoming messages on this node, and connect to remote nodes and return
MessageSender
s to send message to them.
- MessageListener<T> - Interface in edu.snu.coral.runtime.common.message
-
- MessageParameters - Class in edu.snu.coral.runtime.common.message
-
Parameters for message components.
- MessageParameters() - Constructor for class edu.snu.coral.runtime.common.message.MessageParameters
-
- MessageParameters.SenderId - Class in edu.snu.coral.runtime.common.message
-
Id of the sender.
- MessageSender<T> - Interface in edu.snu.coral.runtime.common.message
-
- MetricCollectionBarrierTask - Class in edu.snu.coral.runtime.common.plan.physical
-
MetricCollectionBarrierTask.
- MetricCollectionBarrierVertex<T> - Class in edu.snu.coral.common.ir.vertex
-
IRVertex that collects statistics to send them to the optimizer for dynamic optimization.
- MetricCollectionBarrierVertex() - Constructor for class edu.snu.coral.common.ir.vertex.MetricCollectionBarrierVertex
-
Constructor for dynamic optimization vertex.
- MetricCollectionProperty - Class in edu.snu.coral.common.ir.edge.executionproperty
-
MetricCollection ExecutionProperty.
- MetricCollectionProperty.Value - Enum in edu.snu.coral.common.ir.edge.executionproperty
-
Possible values of MetricCollection ExecutionProperty.
- MetricData - Class in edu.snu.coral.runtime.common.metric
-
MetricData that holds executor side metrics.
- MetricData(String, Map<String, Object>) - Constructor for class edu.snu.coral.runtime.common.metric.MetricData
-
Constructor.
- MetricDataBuilder - Class in edu.snu.coral.runtime.common.metric
-
MetricData Builder.
- MetricDataBuilder(String) - Constructor for class edu.snu.coral.runtime.common.metric.MetricDataBuilder
-
Constructor.
- MetricFlushPeriod - Class in edu.snu.coral.runtime.common.metric.parameter
-
Metric flushing period.
- MetricFlushPeriod() - Constructor for class edu.snu.coral.runtime.common.metric.parameter.MetricFlushPeriod
-
- MetricManagerMaster - Class in edu.snu.coral.runtime.master
-
A default metric message handler.
- MetricManagerWorker - Class in edu.snu.coral.runtime.executor
-
Metric sender that periodically flushes the collected metrics to Driver.
- MetricMessageHandler - Interface in edu.snu.coral.runtime.master
-
Metric message handler.
- MetricMessageSender - Interface in edu.snu.coral.runtime.executor
-
Interface for metric sender.
- metrics() - Method in class edu.snu.coral.compiler.frontend.beam.CoralPipelineResult
-
- min(Comparator<T>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- MultinomialLogisticRegression - Class in edu.snu.coral.examples.beam
-
Sample Multinomial Logistic Regression application.
- MultinomialLogisticRegression.ApplyGradient - Class in edu.snu.coral.examples.beam
-
DoFn class that applies the gradient to the model.
- MultinomialLogisticRegression.CalculateGradient - Class in edu.snu.coral.examples.beam
-
Calculate Gradient.
- MultinomialLogisticRegression.CombineFunction - Class in edu.snu.coral.examples.beam
-
Combine Function for two Double arrays.
- MultinomialLogisticRegression.CombineFunctionForIterable - Class in edu.snu.coral.examples.beam
-
Combine Function for Iterable of gradients.
- MultinomialLogisticRegression.UpdateModel - Class in edu.snu.coral.examples.beam
-
+ Composite transform that wraps the transforms inside the loop.
- of(CompressionProperty.Compression) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.CompressionProperty
-
Static method exposing the constructor.
- of(DataCommunicationPatternProperty.Value) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.DataCommunicationPatternProperty
-
Static method exposing the constructor.
- of(DataFlowModelProperty.Value) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.DataFlowModelProperty
-
Static method exposing the constructor.
- of(DataStoreProperty.Value) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.DataStoreProperty
-
Static method exposing the constructor.
- of(KeyExtractor) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.KeyExtractorProperty
-
Static method exposing the constructor.
- of(MetricCollectionProperty.Value) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.MetricCollectionProperty
-
Static method exposing the constructor.
- of(PartitionerProperty.Value) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.PartitionerProperty
-
Static method exposing the constructor.
- of(UsedDataHandlingProperty.Value) - Static method in class edu.snu.coral.common.ir.edge.executionproperty.UsedDataHandlingProperty
-
Static method exposing the constructor.
- of(IREdge, DataCommunicationPatternProperty.Value) - Static method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
Static initializer for irEdges.
- of(IRVertex) - Static method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
Static initializer for irVertex.
- of(DynamicOptimizationProperty.Value) - Static method in class edu.snu.coral.common.ir.vertex.executionproperty.DynamicOptimizationProperty
-
Static method exposing the constructor.
- of(String) - Static method in class edu.snu.coral.common.ir.vertex.executionproperty.ExecutorPlacementProperty
-
Static method exposing the constructor.
- of(Integer) - Static method in class edu.snu.coral.common.ir.vertex.executionproperty.ParallelismProperty
-
Static method exposing the constructor.
- of(Integer) - Static method in class edu.snu.coral.common.ir.vertex.executionproperty.ScheduleGroupIndexProperty
-
Static method exposing the constructor.
- of(Integer) - Static method in class edu.snu.coral.common.ir.vertex.executionproperty.StageIdProperty
-
Static method exposing the constructor.
- of(A, B) - Static method in class edu.snu.coral.common.Pair
-
Static initializer of the Pair class.
- of(Coder<A>, Coder<B>) - Static method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
static initializer of the class.
- of(SparkContext, Iterable<T>, Integer) - Static method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
Static method to create a JavaRDD object from an iterable object.
- of(SparkContext, Dataset<T>) - Static method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
Static method to create a JavaRDD object from a Dataset.
- of(SparkContext) - Static method in class edu.snu.coral.compiler.frontend.spark.core.RDD
-
Static method to create a RDD object.
- of(int, int) - Static method in class edu.snu.coral.runtime.common.data.HashRange
-
- onBlockStateChanged(String, BlockState.State, String) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster
-
Deals with state change of a block.
- onContainerAllocated(String, AllocatedEvaluator, Configuration) - Method in class edu.snu.coral.runtime.master.resource.ContainerManager
-
Take the necessary actions in container manager once a container a is allocated.
- onContainerAllocated(String, AllocatedEvaluator, Configuration) - Method in class edu.snu.coral.runtime.master.RuntimeMaster
-
Called when a container is allocated for this runtime.
- onData(Iterator<T>, String) - Method in class edu.snu.coral.common.ir.vertex.transform.RelayTransform
-
- onData(Iterator<I>, String) - Method in interface edu.snu.coral.common.ir.vertex.transform.Transform
-
On data received.
- onData(Iterator<I>, String) - Method in class edu.snu.coral.compiler.frontend.beam.transform.CreateViewTransform
-
- onData(Iterator<I>, String) - Method in class edu.snu.coral.compiler.frontend.beam.transform.DoTransform
-
- onData(Iterator<T>, String) - Method in class edu.snu.coral.compiler.frontend.beam.transform.FlattenTransform
-
- onData(Iterator<I>, String) - Method in class edu.snu.coral.compiler.frontend.beam.transform.GroupByKeyTransform
-
- onData(Iterator<T>, String) - Method in class edu.snu.coral.compiler.frontend.beam.transform.WindowTransform
-
- onData(Iterator<T>, String) - Method in class edu.snu.coral.compiler.frontend.spark.transform.CollectTransform
-
- onData(Iterator<T>, String) - Method in class edu.snu.coral.compiler.frontend.spark.transform.FlatMapTransform
-
- onData(Iterator<Tuple2<K, V>>, String) - Method in class edu.snu.coral.compiler.frontend.spark.transform.GroupByKeyTransform
-
- onData(Iterator<T>, String) - Method in class edu.snu.coral.compiler.frontend.spark.transform.MapToPairTransform
-
- onData(Iterator<I>, String) - Method in class edu.snu.coral.compiler.frontend.spark.transform.MapTransform
-
- onData(Iterator<Tuple2<K, V>>, String) - Method in class edu.snu.coral.compiler.frontend.spark.transform.ReduceByKeyTransform
-
- onData(Iterator<T>, String) - Method in class edu.snu.coral.compiler.frontend.spark.transform.ReduceTransform
-
- onData(Iterator<I>, String) - Method in class edu.snu.coral.compiler.optimizer.examples.EmptyComponents.EmptyTransform
-
- onExecutorAdded(String) - Method in class edu.snu.coral.runtime.master.scheduler.BatchSingleJobScheduler
-
- onExecutorAdded(String) - Method in class edu.snu.coral.runtime.master.scheduler.RoundRobinSchedulingPolicy
-
- onExecutorAdded(String) - Method in interface edu.snu.coral.runtime.master.scheduler.Scheduler
-
Called when an executor is added to Runtime, so that the extra resource can be used to execute the job.
- onExecutorAdded(String) - Method in interface edu.snu.coral.runtime.master.scheduler.SchedulingPolicy
-
Adds the executorId to the pool of available executors.
- onExecutorFailed() - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- onExecutorFailed(String) - Method in class edu.snu.coral.runtime.master.RuntimeMaster
-
Called when an executor fails due to container failure on this runtime.
- onExecutorLaunched(ActiveContext) - Method in class edu.snu.coral.runtime.master.resource.ContainerManager
-
Initializes master's connection to the executor once launched.
- onExecutorLaunched(ActiveContext) - Method in class edu.snu.coral.runtime.master.RuntimeMaster
-
Called when an executor is launched on a container for this runtime.
- onExecutorRemoved(String) - Method in class edu.snu.coral.runtime.master.resource.ContainerManager
-
- onExecutorRemoved(String) - Method in class edu.snu.coral.runtime.master.scheduler.BatchSingleJobScheduler
-
- onExecutorRemoved(String) - Method in class edu.snu.coral.runtime.master.scheduler.RoundRobinSchedulingPolicy
-
- onExecutorRemoved(String) - Method in interface edu.snu.coral.runtime.master.scheduler.Scheduler
-
Called when an executor is removed from Runtime, so that faults related to the removal can be handled.
- onExecutorRemoved(String) - Method in interface edu.snu.coral.runtime.master.scheduler.SchedulingPolicy
-
Deletes the executorId from the pool of available executors.
- onFailure(long, Throwable) - Method in class edu.snu.coral.runtime.common.ReplyFutureMap
-
Called for a failure in request-reply communication.
- onJobScheduled(PhysicalPlan) - Method in interface edu.snu.coral.runtime.master.scheduler.PendingTaskGroupQueue
-
Registers a job to this queue in case the queue needs to understand the topology of the job DAG.
- onJobScheduled(PhysicalPlan) - Method in class edu.snu.coral.runtime.master.scheduler.SingleJobTaskGroupQueue
-
- onJobStateChanged(JobState.State) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
Updates the state of the job.
- onMessage(T) - Method in interface edu.snu.coral.runtime.common.message.MessageListener
-
Called back when a message is received.
- onMessage(ControlMessage.Message) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster.PartitionManagerMasterControlMessageReceiver
-
- onMessage(ControlMessage.Message) - Method in class edu.snu.coral.runtime.master.RuntimeMaster.MasterControlMessageReceiver
-
- onMessageWithContext(T, MessageContext) - Method in interface edu.snu.coral.runtime.common.message.MessageListener
-
Called back when a message is received, and return a response using
MessageContext
.
- onMessageWithContext(ControlMessage.Message, MessageContext) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster.PartitionManagerMasterControlMessageReceiver
-
- onMessageWithContext(ControlMessage.Message, MessageContext) - Method in class edu.snu.coral.runtime.master.RuntimeMaster.MasterControlMessageReceiver
-
- onMetricMessageReceived(String, String) - Method in class edu.snu.coral.runtime.master.MetricManagerMaster
-
- onMetricMessageReceived(String, String) - Method in interface edu.snu.coral.runtime.master.MetricMessageHandler
-
Handle the received metric message.
- onNext(JobMessage) - Method in class edu.snu.coral.client.CoralClient.JobMessageHandler
-
- onNext(ContextStart) - Method in class edu.snu.coral.driver.CoralContext.ContextStartHandler
-
- onNext(ContextStop) - Method in class edu.snu.coral.driver.CoralContext.ContextStopHandler
-
- onNext(ActiveContext) - Method in class edu.snu.coral.driver.CoralDriver.ActiveContextHandler
-
- onNext(AllocatedEvaluator) - Method in class edu.snu.coral.driver.CoralDriver.AllocatedEvaluatorHandler
-
- onNext(StopTime) - Method in class edu.snu.coral.driver.CoralDriver.DriverStopHandler
-
- onNext(FailedContext) - Method in class edu.snu.coral.driver.CoralDriver.FailedContextHandler
-
- onNext(FailedEvaluator) - Method in class edu.snu.coral.driver.CoralDriver.FailedEvaluatorHandler
-
- onNext(StartTime) - Method in class edu.snu.coral.driver.CoralDriver.StartHandler
-
- onNext(DynamicOptimizationEvent) - Method in class edu.snu.coral.runtime.common.eventhandler.DynamicOptimizationEventHandler
-
- onNext(UpdatePhysicalPlanEvent) - Method in class edu.snu.coral.runtime.master.eventhandler.UpdatePhysicalPlanEventHandler
-
- onProducerTaskGroupFailed(String) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster
-
To be called when a potential producer task group fails.
- onProducerTaskGroupScheduled(String) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster
-
To be called when a potential producer task group is scheduled.
- onPullRequest(BlockOutputStream<?>) - Method in class edu.snu.coral.runtime.executor.data.BlockManagerWorker
-
Respond to a pull request by another executor.
- onPushNotification(BlockInputStream) - Method in class edu.snu.coral.runtime.executor.data.BlockManagerWorker
-
Respond to a push notification by another executor.
- onStageStateChanged(String, StageState.State) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
Updates the state of a stage.
- onSuccessMessage(long, T) - Method in class edu.snu.coral.runtime.common.ReplyFutureMap
-
Called by message receiver, for a successful reply message.
- onTaskGroupExecutionComplete(String) - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- onTaskGroupExecutionComplete(String, String) - Method in class edu.snu.coral.runtime.master.scheduler.RoundRobinSchedulingPolicy
-
- onTaskGroupExecutionComplete(String, String) - Method in interface edu.snu.coral.runtime.master.scheduler.SchedulingPolicy
-
Marks the taskGroup's completion in the executor.
- onTaskGroupExecutionFailed(String) - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- onTaskGroupExecutionFailed(String, String) - Method in class edu.snu.coral.runtime.master.scheduler.RoundRobinSchedulingPolicy
-
- onTaskGroupExecutionFailed(String, String) - Method in interface edu.snu.coral.runtime.master.scheduler.SchedulingPolicy
-
Marks the taskGroup's failure in the executor.
- onTaskGroupScheduled(ScheduledTaskGroup) - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- onTaskGroupStateChanged(TaskGroupState.State, Optional<String>, Optional<TaskGroupState.RecoverableFailureCause>) - Method in class edu.snu.coral.runtime.executor.TaskGroupStateManager
-
Updates the state of the task group.
- onTaskGroupStateChanged(String, TaskGroupState.State) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
Updates the state of a task group.
- onTaskGroupStateChanged(String, String, TaskGroupState.State, int, String, TaskGroupState.RecoverableFailureCause) - Method in class edu.snu.coral.runtime.master.scheduler.BatchSingleJobScheduler
-
Receives a ControlMessage.TaskGroupStateChangedMsg
from an executor.
- onTaskGroupStateChanged(String, String, TaskGroupState.State, int, String, TaskGroupState.RecoverableFailureCause) - Method in interface edu.snu.coral.runtime.master.scheduler.Scheduler
-
Called when a TaskGroup's execution state changes.
- onTaskStateChanged(String, TaskState.State, Optional<TaskGroupState.RecoverableFailureCause>) - Method in class edu.snu.coral.runtime.executor.TaskGroupStateManager
-
Updates the state of a task.
- open(String) - Static method in class edu.snu.coral.runtime.executor.data.metadata.RemoteFileMetadata
-
Opens a existing block metadata in file.
- OperatorTask - Class in edu.snu.coral.runtime.common.plan.physical
-
OperatorTask.
- OperatorTask(String, String, Transform) - Constructor for class edu.snu.coral.runtime.common.plan.physical.OperatorTask
-
Constructor.
- OperatorVertex - Class in edu.snu.coral.common.ir.vertex
-
IRVertex that transforms input data.
- OperatorVertex(Transform) - Constructor for class edu.snu.coral.common.ir.vertex.OperatorVertex
-
Constructor of OperatorVertex.
- OptimizationPolicy() - Constructor for class edu.snu.coral.conf.JobConf.OptimizationPolicy
-
- optimize(DAG<IRVertex, IREdge>, Policy, String) - Static method in class edu.snu.coral.compiler.optimizer.CompiletimeOptimizer
-
Optimize function.
- OutputCollector<O> - Interface in edu.snu.coral.common.ir
-
Interface through which Transform emits outputs.
- OutputCollectorImpl<O> - Class in edu.snu.coral.runtime.executor.datatransfer
-
Output Collector Implementation.
- OutputCollectorImpl() - Constructor for class edu.snu.coral.runtime.executor.datatransfer.OutputCollectorImpl
-
Constructor of a new OutputCollector.
- OutputWriter - Class in edu.snu.coral.runtime.executor.datatransfer
-
Represents the output data transfer from a task.
- OutputWriter(int, int, String, IRVertex, RuntimeEdge<?>, BlockManagerWorker) - Constructor for class edu.snu.coral.runtime.executor.datatransfer.OutputWriter
-
- PadoCompositePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.composite
-
A series of passes to support Pado optimization.
- PadoCompositePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.PadoCompositePass
-
Default constructor.
- PadoEdgeDataFlowModelPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Pado pass for tagging edges with DataFlowModel ExecutionProperty.
- PadoEdgeDataFlowModelPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.PadoEdgeDataFlowModelPass
-
Default constructor.
- PadoEdgeDataStorePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Pado pass for tagging edges with DataStore ExecutionProperty.
- PadoEdgeDataStorePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.PadoEdgeDataStorePass
-
Default constructor.
- PadoPolicy - Class in edu.snu.coral.compiler.optimizer.policy
-
A policy to perform Pado optimization that uses transient resources on data centers.
- PadoPolicy() - Constructor for class edu.snu.coral.compiler.optimizer.policy.PadoPolicy
-
Default constructor.
- PadoVertexExecutorPlacementPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Pado pass for tagging vertices.
- PadoVertexExecutorPlacementPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.PadoVertexExecutorPlacementPass
-
Default constructor.
- Pair<A,B> - Class in edu.snu.coral.common
-
Pair class.
- PairCoder<A,B> - Class in edu.snu.coral.compiler.frontend.beam.coder
-
- ParallelismProperty - Class in edu.snu.coral.common.ir.vertex.executionproperty
-
Parallelism ExecutionProperty.
- parallelize(List<T>, int) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaSparkContext
-
Initiate a JavaRDD with the number of parallelism.
- ParseLine(Boolean) - Constructor for class edu.snu.coral.examples.beam.AlternatingLeastSquare.ParseLine
-
Constructor for Parseline DoFn class.
- Partition<T,K> - Interface in edu.snu.coral.runtime.executor.data
-
A collection of data elements.
- partition(Iterable, int, KeyExtractor) - Method in class edu.snu.coral.runtime.executor.data.partitioner.DataSkewHashPartitioner
-
- partition(Iterable, int, KeyExtractor) - Method in class edu.snu.coral.runtime.executor.data.partitioner.HashPartitioner
-
- partition(Iterable, int, KeyExtractor) - Method in class edu.snu.coral.runtime.executor.data.partitioner.IntactPartitioner
-
- partition(Iterable, int, KeyExtractor) - Method in interface edu.snu.coral.runtime.executor.data.partitioner.Partitioner
-
Divides the output data from a task into multiple blocks.
- partitioner() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- Partitioner - Interface in edu.snu.coral.runtime.executor.data.partitioner
-
This interface represents the way of partitioning output data from a source task.
- PartitionerProperty - Class in edu.snu.coral.common.ir.edge.executionproperty
-
Partitioner ExecutionProperty.
- PartitionerProperty.Value - Enum in edu.snu.coral.common.ir.edge.executionproperty
-
Possible values of Partitioner ExecutionProperty.
- PartitionManagerMasterControlMessageReceiver() - Constructor for class edu.snu.coral.runtime.master.BlockManagerMaster.PartitionManagerMasterControlMessageReceiver
-
- PartitionMetadata<K extends Serializable> - Class in edu.snu.coral.runtime.executor.data.metadata
-
This class represents a metadata for a partition.
- PartitionMetadata(K, int, long, long) - Constructor for class edu.snu.coral.runtime.executor.data.metadata.PartitionMetadata
-
Constructor.
- partitions() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- PartitionTransportClientNumThreads() - Constructor for class edu.snu.coral.conf.JobConf.PartitionTransportClientNumThreads
-
- PartitionTransportServerBacklog() - Constructor for class edu.snu.coral.conf.JobConf.PartitionTransportServerBacklog
-
- PartitionTransportServerNumListeningThreads() - Constructor for class edu.snu.coral.conf.JobConf.PartitionTransportServerNumListeningThreads
-
- PartitionTransportServerNumWorkingThreads() - Constructor for class edu.snu.coral.conf.JobConf.PartitionTransportServerNumWorkingThreads
-
- PartitionTransportServerPort() - Constructor for class edu.snu.coral.conf.JobConf.PartitionTransportServerPort
-
- pathExistsBetween(V, V) - Method in class edu.snu.coral.common.dag.DAG
-
Function checks whether there is a path between two vertices.
- peek() - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.ClosableBlockingQueue
-
Retrieves, but does not removes, the head of this queue, waiting if necessary.
- PendingTaskGroupQueue - Interface in edu.snu.coral.runtime.master.scheduler
-
Keep tracks of all pending task groups.
- persist(StorageLevel) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- PersistentConnectionToMasterMap - Class in edu.snu.coral.runtime.common.message
-
Persistent connection for sending messages to master.
- PersistentConnectionToMasterMap(MessageEnvironment) - Constructor for class edu.snu.coral.runtime.common.message.PersistentConnectionToMasterMap
-
- PhysicalPlan - Class in edu.snu.coral.runtime.common.plan.physical
-
A job's physical plan, to be executed by the Runtime.
- PhysicalPlan(String, DAG<PhysicalStage, PhysicalStageEdge>, Map<Task, IRVertex>) - Constructor for class edu.snu.coral.runtime.common.plan.physical.PhysicalPlan
-
Constructor.
- PhysicalPlanGenerationException - Exception in edu.snu.coral.common.exception
-
PhysicalPlanGenerationException.
- PhysicalPlanGenerationException(String) - Constructor for exception edu.snu.coral.common.exception.PhysicalPlanGenerationException
-
PhysicalPlanGenerationException.
- PhysicalPlanGenerationException(Throwable) - Constructor for exception edu.snu.coral.common.exception.PhysicalPlanGenerationException
-
PhysicalPlanGenerationException.
- PhysicalPlanGenerator - Class in edu.snu.coral.runtime.common.plan.physical
-
A function that converts an IR DAG to physical DAG.
- PhysicalStage - Class in edu.snu.coral.runtime.common.plan.physical
-
PhysicalStage.
- PhysicalStage(String, DAG<Task, RuntimeEdge<Task>>, int, int, String) - Constructor for class edu.snu.coral.runtime.common.plan.physical.PhysicalStage
-
Constructor.
- PhysicalStageEdge - Class in edu.snu.coral.runtime.common.plan.physical
-
Contains information stage boundary
StageEdge
.
- PhysicalStageEdge(String, ExecutionPropertyMap, IRVertex, IRVertex, PhysicalStage, PhysicalStage, Coder, Boolean) - Constructor for class edu.snu.coral.runtime.common.plan.physical.PhysicalStageEdge
-
Constructor.
- Policy - Interface in edu.snu.coral.compiler.optimizer.policy
-
An interface for policies, each of which is composed of a list of static optimization passes.
- PolicyBuilder - Class in edu.snu.coral.compiler.optimizer.policy
-
A builder for policies.
- PolicyBuilder() - Constructor for class edu.snu.coral.compiler.optimizer.policy.PolicyBuilder
-
Default constructor.
- PolicyBuilder(Boolean) - Constructor for class edu.snu.coral.compiler.optimizer.policy.PolicyBuilder
-
Constructor.
- prepare(Transform.Context, OutputCollector<T>) - Method in class edu.snu.coral.common.ir.vertex.transform.RelayTransform
-
- prepare(Transform.Context, OutputCollector<O>) - Method in interface edu.snu.coral.common.ir.vertex.transform.Transform
-
Prepare the transform.
- prepare(Transform.Context, OutputCollector<O>) - Method in class edu.snu.coral.compiler.frontend.beam.transform.CreateViewTransform
-
- prepare(Transform.Context, OutputCollector<O>) - Method in class edu.snu.coral.compiler.frontend.beam.transform.DoTransform
-
- prepare(Transform.Context, OutputCollector<T>) - Method in class edu.snu.coral.compiler.frontend.beam.transform.FlattenTransform
-
- prepare(Transform.Context, OutputCollector<KV<Object, List>>) - Method in class edu.snu.coral.compiler.frontend.beam.transform.GroupByKeyTransform
-
- prepare(Transform.Context, OutputCollector<T>) - Method in class edu.snu.coral.compiler.frontend.beam.transform.WindowTransform
-
- prepare(Transform.Context, OutputCollector<T>) - Method in class edu.snu.coral.compiler.frontend.spark.transform.CollectTransform
-
- prepare(Transform.Context, OutputCollector<U>) - Method in class edu.snu.coral.compiler.frontend.spark.transform.FlatMapTransform
-
- prepare(Transform.Context, OutputCollector<Tuple2<K, Iterable<V>>>) - Method in class edu.snu.coral.compiler.frontend.spark.transform.GroupByKeyTransform
-
- prepare(Transform.Context, OutputCollector<Tuple2<K, V>>) - Method in class edu.snu.coral.compiler.frontend.spark.transform.MapToPairTransform
-
- prepare(Transform.Context, OutputCollector<O>) - Method in class edu.snu.coral.compiler.frontend.spark.transform.MapTransform
-
- prepare(Transform.Context, OutputCollector<Tuple2<K, V>>) - Method in class edu.snu.coral.compiler.frontend.spark.transform.ReduceByKeyTransform
-
- prepare(Transform.Context, OutputCollector<T>) - Method in class edu.snu.coral.compiler.frontend.spark.transform.ReduceTransform
-
- prepare(Transform.Context, OutputCollector<O>) - Method in class edu.snu.coral.compiler.optimizer.examples.EmptyComponents.EmptyTransform
-
- PrimitiveCompositePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.composite
-
A series of primitive passes that is applied commonly to all policies.
- PrimitiveCompositePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.PrimitiveCompositePass
-
Default constructor.
- processElement(DoFn<KV<Integer, Pair<List<Integer>, List<Double>>>, KV<Integer, List<Double>>>.ProcessContext) - Method in class edu.snu.coral.examples.beam.AlternatingLeastSquare.CalculateNextMatrix
-
ProcessElement method for BEAM.
- processElement(DoFn<String, KV<Integer, Pair<List<Integer>, List<Double>>>>.ProcessContext) - Method in class edu.snu.coral.examples.beam.AlternatingLeastSquare.ParseLine
-
ProcessElement method for BEAM.
- processElement(DoFn<KV<Integer, Iterable<List<Double>>>, KV<Integer, List<Double>>>.ProcessContext) - Method in class edu.snu.coral.examples.beam.AlternatingLeastSquare.UngroupSingleVectorList
-
- processElement(DoFn<KV<Integer, CoGbkResult>, KV<Integer, List<Double>>>.ProcessContext) - Method in class edu.snu.coral.examples.beam.MultinomialLogisticRegression.ApplyGradient
-
ProcessElement method for BEAM.
- processElement(DoFn<String, KV<Integer, List<Double>>>.ProcessContext) - Method in class edu.snu.coral.examples.beam.MultinomialLogisticRegression.CalculateGradient
-
ProcessElement method for BEAM.
- propertiesToJSON() - Method in class edu.snu.coral.common.dag.Edge
-
- propertiesToJSON() - Method in class edu.snu.coral.common.dag.Vertex
-
- propertiesToJSON() - Method in class edu.snu.coral.common.ir.edge.IREdge
-
- propertiesToJSON() - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
- propertiesToJSON() - Method in class edu.snu.coral.common.ir.vertex.MetricCollectionBarrierVertex
-
- propertiesToJSON() - Method in class edu.snu.coral.common.ir.vertex.OperatorVertex
-
- propertiesToJSON() - Method in class edu.snu.coral.compiler.frontend.beam.source.BeamBoundedSourceVertex
-
- propertiesToJSON() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStage
-
- propertiesToJSON() - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStageEdge
-
- propertiesToJSON() - Method in class edu.snu.coral.runtime.common.plan.physical.Task
-
- propertiesToJSON() - Method in class edu.snu.coral.runtime.common.plan.RuntimeEdge
-
- propertiesToJSON() - Method in class edu.snu.coral.runtime.common.plan.stage.Stage
-
- propertiesToJSON() - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdge
-
- publish(LogRecord) - Method in class edu.snu.coral.driver.RemoteClientMessageLoggingHandler
-
TODO #XXX: buffer the log messages for performance.
- PubSubEventHandlerWrapper - Class in edu.snu.coral.common.eventhandler
-
Wrapper class with a pub/sub event handler.
- put(ExecutionProperty<?>) - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
Put the given execution property in the ExecutionPropertyMap.
- put(T) - Method in class edu.snu.coral.runtime.executor.data.blocktransfer.ClosableBlockingQueue
-
Adds an element.
- putPartitions(Iterable<NonSerializedPartition<K>>) - Method in interface edu.snu.coral.runtime.executor.data.block.Block
-
- putPartitions(Iterable<NonSerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.block.FileBlock
-
- putPartitions(Iterable<NonSerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.block.NonSerializedMemoryBlock
-
- putPartitions(Iterable<NonSerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.block.SerializedMemoryBlock
-
- putPartitions(String, Iterable<Partition>, DataStoreProperty.Value) - Method in class edu.snu.coral.runtime.executor.data.BlockManagerWorker
-
Store an iterable of data partitions to a block in the target BlockStore
.
- putPartitions(String, Iterable<NonSerializedPartition<K>>) - Method in interface edu.snu.coral.runtime.executor.data.stores.BlockStore
-
- putPartitions(String, Iterable<NonSerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
- putPartitions(String, Iterable<NonSerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalBlockStore
-
- putSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in interface edu.snu.coral.runtime.executor.data.block.Block
-
- putSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.block.FileBlock
-
- putSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.block.NonSerializedMemoryBlock
-
- putSerializedPartitions(Iterable<SerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.block.SerializedMemoryBlock
-
- putSerializedPartitions(String, Iterable<SerializedPartition<K>>) - Method in interface edu.snu.coral.runtime.executor.data.stores.BlockStore
-
- putSerializedPartitions(String, Iterable<SerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
- putSerializedPartitions(String, Iterable<SerializedPartition<K>>) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalBlockStore
-
- randomSplit(double[]) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- randomSplit(double[], long) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- rangeBeginInclusive() - Method in class edu.snu.coral.runtime.common.data.HashRange
-
- rangeBeginInclusive() - Method in interface edu.snu.coral.runtime.common.data.KeyRange
-
- rangeEndExclusive() - Method in class edu.snu.coral.runtime.common.data.HashRange
-
- rangeEndExclusive() - Method in interface edu.snu.coral.runtime.common.data.KeyRange
-
- RDD<T> - Class in edu.snu.coral.compiler.frontend.spark.core
-
RDD for Coral.
- read() - Method in interface edu.snu.coral.common.ir.Readable
-
Method to read data from the source.
- read() - Method in class edu.snu.coral.compiler.frontend.spark.sql.SparkSession
-
- read() - Method in class edu.snu.coral.runtime.executor.datatransfer.InputReader
-
Reads input data depending on the communication pattern of the srcVertex.
- Readable<O> - Interface in edu.snu.coral.common.ir
-
Interface for readable.
- ReadablesWrapper<O> - Interface in edu.snu.coral.common.ir
-
A wrapper interface for parallel
Readable
s.
- reduce(Function2<T, T, T>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
Reduce action.
- reduceByKey(Function2<V, V, V>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaPairRDD
-
- ReduceByKeyTransform<K,V> - Class in edu.snu.coral.compiler.frontend.spark.transform
-
Transform for reduce by key transformation.
- ReduceByKeyTransform(Function2<V, V, V>) - Constructor for class edu.snu.coral.compiler.frontend.spark.transform.ReduceByKeyTransform
-
Constructor.
- reduceIterator(Iterator<T>, Function2<T, T, T>) - Static method in class edu.snu.coral.compiler.frontend.spark.transform.ReduceTransform
-
Reduce the iterator elements into a single object.
- ReduceTransform<T> - Class in edu.snu.coral.compiler.frontend.spark.transform
-
Reduce Transform for Spark.
- ReduceTransform(Function2<T, T, T>) - Constructor for class edu.snu.coral.compiler.frontend.spark.transform.ReduceTransform
-
Constructor.
- registerByteSizeObserver(Pair<A, B>, ElementByteSizeObserver) - Method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
Notifies ElementByteSizeObserver about the byte size of the
encoded value using this coder.
- registerCoder(String, Coder) - Method in class edu.snu.coral.runtime.executor.data.CoderManager
-
Register a coder for runtime edge.
- registerCompileTimePass(CompileTimePass) - Method in class edu.snu.coral.compiler.optimizer.policy.PolicyBuilder
-
Register compile time pass.
- registerRuntimePass(RuntimePass<?>, CompileTimePass) - Method in class edu.snu.coral.compiler.optimizer.policy.PolicyBuilder
-
Register run time passes.
- RelayTransform<T> - Class in edu.snu.coral.common.ir.vertex.transform
-
A
Transform
relays input data from upstream vertex to downstream vertex promptly.
- RelayTransform() - Constructor for class edu.snu.coral.common.ir.vertex.transform.RelayTransform
-
Default constructor.
- RemoteClientMessageLoggingHandler - Class in edu.snu.coral.driver
-
A simple logging handler that forwards messages to REEF client.
- RemoteClientMessageLoggingHandler(JobMessageObserver) - Constructor for class edu.snu.coral.driver.RemoteClientMessageLoggingHandler
-
- RemoteFileMetadata<K extends Serializable> - Class in edu.snu.coral.runtime.executor.data.metadata
-
This class represents a metadata for a remote file block.
- RemoteFileStore - Interface in edu.snu.coral.runtime.executor.data.stores
-
Interface for remote block stores (e.g., GlusterFS, ...).
- remove(ExecutionProperty.Key) - Method in class edu.snu.coral.common.ir.executionproperty.ExecutionPropertyMap
-
remove the execution property.
- removeBlock(String, DataStoreProperty.Value) - Method in class edu.snu.coral.runtime.executor.data.BlockManagerWorker
-
Remove the block from store.
- removeBlock(String) - Method in interface edu.snu.coral.runtime.executor.data.stores.BlockStore
-
Removes a block of data.
- removeBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.GlusterFileStore
-
Removes the file that the target block is stored.
- removeBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.LocalFileStore
-
Removes the file that the target block is stored.
- removeBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.MemoryStore
-
- removeBlock(String) - Method in class edu.snu.coral.runtime.executor.data.stores.SerializedMemoryStore
-
- removeListener(String) - Method in class edu.snu.coral.runtime.common.message.grpc.GrpcMessageEnvironment
-
- removeListener(String) - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageEnvironment
-
- removeListener(String) - Method in interface edu.snu.coral.runtime.common.message.MessageEnvironment
-
- removeListener(String) - Method in class edu.snu.coral.runtime.common.message.ncs.NcsMessageEnvironment
-
- removeTaskGroupsAndDescendants(String) - Method in interface edu.snu.coral.runtime.master.scheduler.PendingTaskGroupQueue
-
Removes a stage and its descendant stages from this queue.
- removeTaskGroupsAndDescendants(String) - Method in class edu.snu.coral.runtime.master.scheduler.SingleJobTaskGroupQueue
-
Removes a stage and its descendant stages from this PQ.
- removeVertex(V) - Method in class edu.snu.coral.common.dag.DAGBuilder
-
Remove the vertex from the list.
- removeWorker(String) - Method in class edu.snu.coral.runtime.master.BlockManagerMaster
-
Manages the block information when a executor is removed.
- repartition(int) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- reply(U) - Method in interface edu.snu.coral.runtime.common.message.MessageContext
-
Send back a reply message.
- ReplyFutureMap<T> - Class in edu.snu.coral.runtime.common
-
Orchestrate message sender and receiver using
CompletableFuture
for asynchronous request-reply communication.
- ReplyFutureMap() - Constructor for class edu.snu.coral.runtime.common.ReplyFutureMap
-
- request(T) - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageSender
-
- request(T) - Method in interface edu.snu.coral.runtime.common.message.MessageSender
-
- requestContainer(int, ResourceSpecification) - Method in class edu.snu.coral.runtime.master.resource.ContainerManager
-
Requests containers/evaluators with the given specifications.
- requestContainer(String) - Method in class edu.snu.coral.runtime.master.RuntimeMaster
-
- RESERVED - Static variable in class edu.snu.coral.common.ir.vertex.executionproperty.ExecutorPlacementProperty
-
- ReshapingPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping
-
A compile-time pass that reshapes the structure of the IR DAG.
- ReshapingPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.ReshapingPass
-
Default constructor.
- ReshapingPass(Set<ExecutionProperty.Key>) - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.ReshapingPass
-
Constructor.
- ResourceSpecification - Class in edu.snu.coral.runtime.master.resource
-
Represents the specifications of a resource.
- ResourceSpecification(String, int, int) - Constructor for class edu.snu.coral.runtime.master.resource.ResourceSpecification
-
- ResourceSpecification.Builder - Class in edu.snu.coral.runtime.master.resource
-
- ReviseInterStageEdgeDataStorePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
Edge data store pass to process inter-stage memory store edges.
- ReviseInterStageEdgeDataStorePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.ReviseInterStageEdgeDataStorePass
-
Default constructor.
- right() - Method in class edu.snu.coral.common.Pair
-
- RoundRobinSchedulingPolicy - Class in edu.snu.coral.runtime.master.scheduler
-
- RoundRobinSchedulingPolicy(ContainerManager, int) - Constructor for class edu.snu.coral.runtime.master.scheduler.RoundRobinSchedulingPolicy
-
- run(Pipeline) - Method in class edu.snu.coral.compiler.frontend.beam.CoralPipelineRunner
-
Method to run the Pipeline.
- run() - Method in class edu.snu.coral.driver.UserApplicationRunner
-
- RUNTIME_MASTER_MESSAGE_LISTENER_ID - Static variable in interface edu.snu.coral.runtime.common.message.MessageEnvironment
-
- RuntimeEdge<V extends Vertex> - Class in edu.snu.coral.runtime.common.plan
-
Represents the edge between vertices in a logical/physical plan in runtime.
- RuntimeEdge(String, ExecutionPropertyMap, V, V, Coder) - Constructor for class edu.snu.coral.runtime.common.plan.RuntimeEdge
-
Constructs the edge given the below parameters.
- RuntimeEdge(String, ExecutionPropertyMap, V, V, Coder, Boolean) - Constructor for class edu.snu.coral.runtime.common.plan.RuntimeEdge
-
Constructs the edge given the below parameters.
- RuntimeEvent - Interface in edu.snu.coral.common.eventhandler
-
An empty interface to indicate events that are sent from Runtime.
- RuntimeEventHandler<T extends RuntimeEvent> - Interface in edu.snu.coral.common.eventhandler
-
Class for handling events sent from Runtime.
- RuntimeIdGenerator - Class in edu.snu.coral.runtime.common
-
ID Generator.
- RuntimeMaster - Class in edu.snu.coral.runtime.master
-
Runtime Master is the central controller of Runtime.
- RuntimeMaster(Scheduler, SchedulerRunner, PendingTaskGroupQueue, ContainerManager, BlockManagerMaster, MetricMessageHandler, MessageEnvironment, String) - Constructor for class edu.snu.coral.runtime.master.RuntimeMaster
-
- RuntimeMaster.MasterControlMessageReceiver - Class in edu.snu.coral.runtime.master
-
Handler for control messages received by Master.
- RuntimeOptimizer - Class in edu.snu.coral.runtime.common.optimizer
-
Runtime optimizer class.
- RuntimePass<T> - Interface in edu.snu.coral.runtime.common.optimizer.pass.runtime
-
Interface for dynamic optimization passes, for dynamically optimizing a physical plan.
- SailfishEdgeDataFlowModelPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A pass to support Sailfish-like shuffle by tagging edges.
- SailfishEdgeDataFlowModelPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.SailfishEdgeDataFlowModelPass
-
Default constructor.
- SailfishEdgeDataStorePass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A pass to support Sailfish-like shuffle by tagging edges.
- SailfishEdgeDataStorePass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.SailfishEdgeDataStorePass
-
Default constructor.
- SailfishEdgeUsedDataHandlingPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A pass to support Sailfish-like shuffle by tagging edges.
- SailfishEdgeUsedDataHandlingPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.SailfishEdgeUsedDataHandlingPass
-
Default constructor.
- SailfishPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.composite
-
A series of passes to support Sailfish-like disk seek batching during shuffle.
- SailfishPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.composite.SailfishPass
-
Default constructor.
- SailfishPolicy - Class in edu.snu.coral.compiler.optimizer.policy
-
A policy to demonstrate the Sailfish optimization, that batches disk seek during data shuffle.
- SailfishPolicy() - Constructor for class edu.snu.coral.compiler.optimizer.policy.SailfishPolicy
-
Default constructor.
- SailfishRelayReshapingPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping
-
Pass to modify the DAG for a job to batch the disk seek.
- SailfishRelayReshapingPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.reshaping.SailfishRelayReshapingPass
-
Default constructor.
- sample(boolean, double) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- sample(boolean, double, long) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- saveAsObjectFile(String) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- saveAsTextFile(String) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- saveAsTextFile(String, Class<? extends CompressionCodec>) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- ScheduledTaskGroup - Class in edu.snu.coral.runtime.common.plan.physical
-
A ScheduledTaskGroup is a grouping of
Task
that belong to a stage.
- ScheduledTaskGroup(String, byte[], String, List<PhysicalStageEdge>, List<PhysicalStageEdge>, int, String) - Constructor for class edu.snu.coral.runtime.common.plan.physical.ScheduledTaskGroup
-
Constructor.
- ScheduleGroupIndexProperty - Class in edu.snu.coral.common.ir.vertex.executionproperty
-
ScheduleGroupIndex ExecutionProperty.
- ScheduleGroupPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A pass for assigning each stages in schedule groups.
- ScheduleGroupPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.ScheduleGroupPass
-
Default constructor.
- scheduleJob(PhysicalPlan, JobStateManager) - Method in class edu.snu.coral.runtime.master.scheduler.BatchSingleJobScheduler
-
Receives a job to schedule.
- scheduleJob(PhysicalPlan, JobStateManager) - Method in interface edu.snu.coral.runtime.master.scheduler.Scheduler
-
Schedules the given job.
- scheduleJob(JobStateManager) - Method in class edu.snu.coral.runtime.master.scheduler.SchedulerRunner
-
- Scheduler - Interface in edu.snu.coral.runtime.master.scheduler
-
- SchedulerRunner - Class in edu.snu.coral.runtime.master.scheduler
-
Takes a TaskGroup from the pending queue and schedules it to an executor.
- SchedulerRunner(SchedulingPolicy, PendingTaskGroupQueue) - Constructor for class edu.snu.coral.runtime.master.scheduler.SchedulerRunner
-
- SchedulerTimeoutMs() - Constructor for class edu.snu.coral.conf.JobConf.SchedulerTimeoutMs
-
- ScheduleSerThread() - Constructor for class edu.snu.coral.conf.JobConf.ScheduleSerThread
-
- scheduleTaskGroup(ScheduledTaskGroup, JobStateManager) - Method in class edu.snu.coral.runtime.master.scheduler.RoundRobinSchedulingPolicy
-
- scheduleTaskGroup(ScheduledTaskGroup, JobStateManager) - Method in interface edu.snu.coral.runtime.master.scheduler.SchedulingPolicy
-
Attempts to schedule the given taskGroup to an executor according to this policy.
- SchedulingException - Exception in edu.snu.coral.common.exception
-
SchedulingException.
- SchedulingException(Throwable) - Constructor for exception edu.snu.coral.common.exception.SchedulingException
-
SchedulingException.
- SchedulingPolicy - Interface in edu.snu.coral.runtime.master.scheduler
-
- send(T) - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageSender
-
- send(T) - Method in interface edu.snu.coral.runtime.common.message.MessageSender
-
- send(String, String) - Method in class edu.snu.coral.runtime.executor.MetricManagerWorker
-
- send(String, String) - Method in interface edu.snu.coral.runtime.executor.MetricMessageSender
-
- sendControlMessage(ControlMessage.Message) - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- SenderId() - Constructor for class edu.snu.coral.runtime.common.message.MessageParameters.SenderId
-
- SerializedDAG() - Constructor for class edu.snu.coral.conf.JobConf.SerializedDAG
-
- SerializedMemoryBlock<K extends Serializable> - Class in edu.snu.coral.runtime.executor.data.block
-
This class represents a block which is serialized and stored in local memory.
- SerializedMemoryBlock(Coder) - Constructor for class edu.snu.coral.runtime.executor.data.block.SerializedMemoryBlock
-
Constructor.
- SerializedMemoryStore - Class in edu.snu.coral.runtime.executor.data.stores
-
Serialize and store data in local memory.
- SerializedPartition<K> - Class in edu.snu.coral.runtime.executor.data
-
A collection of data elements.
- SerializedPartition(K, long, byte[], int) - Constructor for class edu.snu.coral.runtime.executor.data.SerializedPartition
-
Creates a serialized
Partition
having a specific key value.
- serializePartition(Coder, NonSerializedPartition, ByteArrayOutputStream) - Static method in class edu.snu.coral.runtime.executor.data.DataUtil
-
Serializes the elements in a non-serialized partition into an output stream.
- setCapacity(int) - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification.Builder
-
- setCoder(Coder) - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Setter for coder.
- setCommitted(boolean) - Method in class edu.snu.coral.runtime.executor.data.metadata.FileMetadata
-
Set the commit value.
- setContainerType(String) - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification.Builder
-
- setDAGSnapshot(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.common.ir.vertex.MetricCollectionBarrierVertex
-
This is to set the DAG snapshot at the end of the DataSkewCompositePass.
- setDstStage(Stage) - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Setter for the destination stage.
- setDstVertex(IRVertex) - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Setter for the destination vertex.
- setEdgeProperties(ExecutionPropertyMap) - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Setter for edge properties.
- setInDriver() - Static method in class edu.snu.coral.common.ir.IdManager
-
Set the realm of the loaded class as REEF driver.
- setInitialState(Enum) - Method in class edu.snu.coral.common.StateMachine.Builder
-
- setMaxNumberOfIterations(Integer) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Set the maximum number of iterations.
- setMemory(int) - Method in class edu.snu.coral.runtime.master.resource.ResourceSpecification.Builder
-
- setName(String) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- setProperty(ExecutionProperty<?>) - Method in class edu.snu.coral.common.ir.edge.IREdge
-
Set an executionProperty of the IREdge.
- setProperty(ExecutionProperty<?>) - Method in class edu.snu.coral.common.ir.vertex.IRVertex
-
Set an executionProperty of the IRVertex.
- setScheduler(Scheduler) - Method in class edu.snu.coral.runtime.master.eventhandler.UpdatePhysicalPlanEventHandler
-
- setSideInputFlag(Boolean) - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Setter for side input flag.
- setSrcStage(Stage) - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Setter for the source stage.
- setSrcVertex(IRVertex) - Method in class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Setter for the source vertex.
- setState(Enum) - Method in class edu.snu.coral.common.StateMachine
-
Sets the current state as a certain state.
- setTaskGroupIdxToKeyRange(List<KeyRange>) - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalStageEdge
-
Sets the task group idx to key range list.
- setTerminationCondition(IntPredicate) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Set the intPredicate termination condition for the LoopVertex.
- setupListener(String, MessageListener<T>) - Method in class edu.snu.coral.runtime.common.message.grpc.GrpcMessageEnvironment
-
- setupListener(String, MessageListener<T>) - Method in class edu.snu.coral.runtime.common.message.local.LocalMessageEnvironment
-
- setupListener(String, MessageListener<T>) - Method in interface edu.snu.coral.runtime.common.message.MessageEnvironment
-
- setupListener(String, MessageListener<T>) - Method in class edu.snu.coral.runtime.common.message.ncs.NcsMessageEnvironment
-
- ShuffleEdgePushPass - Class in edu.snu.coral.compiler.optimizer.pass.compiletime.annotating
-
A pass for tagging shuffle edges different from the default ones.
- ShuffleEdgePushPass() - Constructor for class edu.snu.coral.compiler.optimizer.pass.compiletime.annotating.ShuffleEdgePushPass
-
Default constructor.
- shutDown() - Method in class edu.snu.coral.runtime.master.resource.ExecutorRepresenter
-
- SingleJobTaskGroupQueue - Class in edu.snu.coral.runtime.master.scheduler
-
Keep tracks of all pending task groups.
- SingleJobTaskGroupQueue() - Constructor for class edu.snu.coral.runtime.master.scheduler.SingleJobTaskGroupQueue
-
- sortBy(Function<T, S>, boolean, int) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- SourceVertex<O> - Class in edu.snu.coral.common.ir.vertex
-
IRVertex that reads data from an external source.
- SourceVertex() - Constructor for class edu.snu.coral.common.ir.vertex.SourceVertex
-
- SparkBoundedSourceVertex<T> - Class in edu.snu.coral.compiler.frontend.spark.source
-
Bounded source vertex for Spark.
- SparkBoundedSourceVertex(Dataset<T>) - Constructor for class edu.snu.coral.compiler.frontend.spark.source.SparkBoundedSourceVertex
-
Constructor.
- SparkBoundedSourceVertex(ReadablesWrapper<T>) - Constructor for class edu.snu.coral.compiler.frontend.spark.source.SparkBoundedSourceVertex
-
Constructor.
- SparkCoder<T> - Class in edu.snu.coral.compiler.frontend.spark.coder
-
Kryo Spark Coder for serialization.
- SparkCoder(Serializer) - Constructor for class edu.snu.coral.compiler.frontend.spark.coder.SparkCoder
-
Default constructor.
- SparkFrontendUtils - Class in edu.snu.coral.compiler.frontend.spark.core.java
-
Utility class for RDDs.
- SparkKeyExtractor - Class in edu.snu.coral.compiler.frontend.spark
-
Extracts the key from a KV element.
- SparkKeyExtractor() - Constructor for class edu.snu.coral.compiler.frontend.spark.SparkKeyExtractor
-
- SparkSession - Class in edu.snu.coral.compiler.frontend.spark.sql
-
A simple version of the Spark session, containing SparkContext that contains SparkConf.
- SparkSession.Builder - Class in edu.snu.coral.compiler.frontend.spark.sql
-
Spark Session Builder.
- Stage - Class in edu.snu.coral.runtime.common.plan.stage
-
Represents a stage in Runtime's execution of a job.
- Stage(String, DAG<IRVertex, IREdge>, int) - Constructor for class edu.snu.coral.runtime.common.plan.stage.Stage
-
Constructor.
- StageBuilder - Class in edu.snu.coral.runtime.common.plan.stage
-
Stage Builder.
- StageBuilder(Integer, int) - Constructor for class edu.snu.coral.runtime.common.plan.stage.StageBuilder
-
- StageEdge - Class in edu.snu.coral.runtime.common.plan.stage
-
Stage Edge.
- StageEdge(String, ExecutionPropertyMap, Stage, Stage, Coder, Boolean, IRVertex, IRVertex) - Constructor for class edu.snu.coral.runtime.common.plan.stage.StageEdge
-
Represents the edge between stages.
- StageEdgeBuilder - Class in edu.snu.coral.runtime.common.plan.stage
-
Stage Edge Builder.
- StageEdgeBuilder(String) - Constructor for class edu.snu.coral.runtime.common.plan.stage.StageEdgeBuilder
-
Represents the edge between vertices in a logical plan.
- StageIdProperty - Class in edu.snu.coral.common.ir.vertex.executionproperty
-
StageId ExecutionProperty.
- stagePartitionIrDAG(DAG<IRVertex, IREdge>) - Method in class edu.snu.coral.runtime.common.plan.physical.PhysicalPlanGenerator
-
We take the stage-partitioned DAG and create actual stage and stage edge objects to create a DAG of stages.
- StageState - Class in edu.snu.coral.runtime.common.state
-
- StageState() - Constructor for class edu.snu.coral.runtime.common.state.StageState
-
- StageState.State - Enum in edu.snu.coral.runtime.common.state
-
StageState.
- StartHandler() - Constructor for class edu.snu.coral.driver.CoralDriver.StartHandler
-
- StateMachine - Class in edu.snu.coral.common
-
A finite state machine that can be created with user defined states and transitions.
- StateMachine.Builder - Class in edu.snu.coral.common
-
Builder that builds a StateMachine.
- StateTranslator - Interface in edu.snu.coral.client
-
A class provides the translation between the state of job and corresponding
ClientEndpoint
.
- storeJSON(String, String, String) - Method in class edu.snu.coral.common.dag.DAG
-
Stores JSON representation of this DAG into a file.
- storeJSON(String, String) - Method in class edu.snu.coral.runtime.master.JobStateManager
-
Stores JSON representation of job state into a file.
- structuralValue(Pair<A, B>) - Method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
- UnboundedSourceTask - Class in edu.snu.coral.runtime.common.plan.physical
-
UnboundedSourceTask.
- UnboundedSourceTask(String, String) - Constructor for class edu.snu.coral.runtime.common.plan.physical.UnboundedSourceTask
-
Constructor.
- UngroupSingleVectorList() - Constructor for class edu.snu.coral.examples.beam.AlternatingLeastSquare.UngroupSingleVectorList
-
- UnknownExecutionStateException - Exception in edu.snu.coral.common.exception
-
UnknownExecutionStateException.
- UnknownExecutionStateException(Throwable) - Constructor for exception edu.snu.coral.common.exception.UnknownExecutionStateException
-
UnknownExecutionStateException.
- UnknownFailureCauseException - Exception in edu.snu.coral.common.exception
-
UnknownFailureCauseException.
- UnknownFailureCauseException(Throwable) - Constructor for exception edu.snu.coral.common.exception.UnknownFailureCauseException
-
UnknownFailureCauseException.
- unpersist() - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- unpersist(boolean) - Method in class edu.snu.coral.compiler.frontend.spark.core.java.JavaRDD
-
- UnrecoverableFailureException - Exception in edu.snu.coral.common.exception
-
UnrecoverableFailureException.
- UnrecoverableFailureException(Throwable) - Constructor for exception edu.snu.coral.common.exception.UnrecoverableFailureException
-
UnrecoverableFailureException.
- unRollIteration(DAGBuilder<IRVertex, IREdge>) - Method in class edu.snu.coral.common.ir.vertex.LoopVertex
-
Method for unrolling an iteration of the LoopVertex.
- UnsupportedBlockStoreException - Exception in edu.snu.coral.common.exception
-
UnsupportedBlockStoreException.
- UnsupportedBlockStoreException(Throwable) - Constructor for exception edu.snu.coral.common.exception.UnsupportedBlockStoreException
-
UnsupportedBlockStoreException.
- UnsupportedCommPatternException - Exception in edu.snu.coral.common.exception
-
UnsupportedCommPatternException.
- UnsupportedCommPatternException(Throwable) - Constructor for exception edu.snu.coral.common.exception.UnsupportedCommPatternException
-
UnsupportedCommPatternException.
- UnsupportedExecutionPropertyException - Exception in edu.snu.coral.common.exception
-
UnsupportedExecutionPropertyException.
- UnsupportedExecutionPropertyException(String) - Constructor for exception edu.snu.coral.common.exception.UnsupportedExecutionPropertyException
-
UnsupportedExecutionPropertyException.
- UnsupportedMethodException - Exception in edu.snu.coral.common.exception
-
UnsupportedMethodException.
- UnsupportedMethodException(String) - Constructor for exception edu.snu.coral.common.exception.UnsupportedMethodException
-
UnsupportedMethodException.
- UnsupportedPartitionerException - Exception in edu.snu.coral.common.exception
-
UnsupportedPartitionerException.
- UnsupportedPartitionerException(Throwable) - Constructor for exception edu.snu.coral.common.exception.UnsupportedPartitionerException
-
UnsupportedPartitionerException.
- updateJob(String, PhysicalPlan, Pair<String, String>) - Method in class edu.snu.coral.runtime.master.scheduler.BatchSingleJobScheduler
-
- updateJob(String, PhysicalPlan, Pair<String, String>) - Method in interface edu.snu.coral.runtime.master.scheduler.Scheduler
-
Receives and updates the scheduler with a new physical plan for a job.
- UpdatePhysicalPlanEvent - Class in edu.snu.coral.runtime.common.eventhandler
-
An event for updating the physical plan in the scheduler.
- UpdatePhysicalPlanEventHandler - Class in edu.snu.coral.runtime.master.eventhandler
-
Class for handling event to update physical plan to the scheduler.
- UsedDataHandlingProperty - Class in edu.snu.coral.common.ir.edge.executionproperty
-
UsedDataHandling ExecutionProperty.
- UsedDataHandlingProperty.Value - Enum in edu.snu.coral.common.ir.edge.executionproperty
-
Possible values of UsedDataHandling ExecutionProperty.
- UserApplicationRunner - Class in edu.snu.coral.driver
-
Compiles and runs User application.
- UserMainArguments() - Constructor for class edu.snu.coral.conf.JobConf.UserMainArguments
-
- UserMainClass() - Constructor for class edu.snu.coral.conf.JobConf.UserMainClass
-
- valueOf(String) - Static method in enum edu.snu.coral.common.dag.DAG.TraversalOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.CompressionProperty.Compression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.DataCommunicationPatternProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.DataFlowModelProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.DataStoreProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.MetricCollectionProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.PartitionerProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.UsedDataHandlingProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.executionproperty.ExecutionProperty.Key
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.common.ir.vertex.executionproperty.DynamicOptimizationProperty.Value
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.runtime.common.state.BlockState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.runtime.common.state.JobState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.runtime.common.state.StageState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.runtime.common.state.TaskGroupState.RecoverableFailureCause
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.runtime.common.state.TaskGroupState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum edu.snu.coral.runtime.common.state.TaskState.State
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum edu.snu.coral.common.dag.DAG.TraversalOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.CompressionProperty.Compression
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.DataCommunicationPatternProperty.Value
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.DataFlowModelProperty.Value
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.DataStoreProperty.Value
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.MetricCollectionProperty.Value
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.PartitionerProperty.Value
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.edge.executionproperty.UsedDataHandlingProperty.Value
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.executionproperty.ExecutionProperty.Key
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.common.ir.vertex.executionproperty.DynamicOptimizationProperty.Value
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.runtime.common.state.BlockState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.runtime.common.state.JobState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.runtime.common.state.StageState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.runtime.common.state.TaskGroupState.RecoverableFailureCause
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.runtime.common.state.TaskGroupState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum edu.snu.coral.runtime.common.state.TaskState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- verifyDeterministic() - Method in class edu.snu.coral.compiler.frontend.beam.coder.PairCoder
-
- Vertex - Class in edu.snu.coral.common.dag
-
A vertex in DAG.
- Vertex(String) - Constructor for class edu.snu.coral.common.dag.Vertex
-
- visitPrimitiveTransform(TransformHierarchy.Node) - Method in class edu.snu.coral.compiler.frontend.beam.CoralPipelineVisitor
-