Uses of Class
org.apache.sysds.runtime.controlprogram.context.ExecutionContext
- 
- 
Uses of ExecutionContext in org.apache.sysds.apiMethods in org.apache.sysds.api with parameters of type ExecutionContext Modifier and Type Method Description static voidScriptExecutorUtils. executeRuntimeProgram(Program rtprog, ExecutionContext ec, DMLConfig dmlconf, int statisticsMaxHeavyHitters, Set<String> outputVariables)Execute the runtime program.
- 
Uses of ExecutionContext in org.apache.sysds.api.mlcontextMethods in org.apache.sysds.api.mlcontext that return ExecutionContext Modifier and Type Method Description ExecutionContextScriptExecutor. getExecutionContext()Obtain the execution context
- 
Uses of ExecutionContext in org.apache.sysds.hops.costMethods in org.apache.sysds.hops.cost with parameters of type ExecutionContext Modifier and Type Method Description static doubleCostEstimationWrapper. getTimeEstimate(ProgramBlock pb, ExecutionContext ec, boolean recursive)static doubleCostEstimationWrapper. getTimeEstimate(Program rtprog, ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.hops.recompileMethods in org.apache.sysds.hops.recompile with parameters of type ExecutionContext Modifier and Type Method Description static booleanRecompiler. checkCPReblock(ExecutionContext ec, String varin)CP Reblock check for spark instructions; in contrast to MR, we can not rely on the input file sizes because inputs might be passed via rdds.static voidRecompiler. executeInMemoryReblock(ExecutionContext ec, String varin, String varout)static voidRecompiler. executeInMemoryReblock(ExecutionContext ec, String varin, String varout, LineageItem litem)static ArrayList<Instruction>Recompiler. recompileHopsDag(StatementBlock sb, ArrayList<Hop> hops, ExecutionContext ec, RecompileStatus status, boolean inplace, boolean replaceLit, long tid)static voidRecompiler. rReplaceLiterals(Hop hop, ExecutionContext ec, boolean scalarsOnly)public interface to package local literal replacement
- 
Uses of ExecutionContext in org.apache.sysds.hops.rewriteMethods in org.apache.sysds.hops.rewrite with parameters of type ExecutionContext Modifier and Type Method Description FederatedResponseRewriteFederatedExecution.PrivacyConstraintRetriever. execute(ExecutionContext ec, Data... data)Reads metadata JSON object, parses privacy constraint and returns the constraint in FederatedResponse.org.apache.commons.lang3.tuple.Pair<String,LineageItem>RewriteFederatedExecution.PrivacyConstraintRetriever. getLineageItem(ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.codegen
- 
Uses of ExecutionContext in org.apache.sysds.runtime.compressMethods in org.apache.sysds.runtime.compress with parameters of type ExecutionContext Modifier and Type Method Description static voidCompressedMatrixBlockFactory. compressAsync(ExecutionContext ec, String varName)static voidCompressedMatrixBlockFactory. compressAsync(ExecutionContext ec, String varName, InstructionTypeCounter ins)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.controlprogramMethods in org.apache.sysds.runtime.controlprogram with parameters of type ExecutionContext Modifier and Type Method Description voidBasicProgramBlock. execute(ExecutionContext ec)voidForProgramBlock. execute(ExecutionContext ec)voidFunctionProgramBlock. execute(ExecutionContext ec)voidIfProgramBlock. execute(ExecutionContext ec)voidParForProgramBlock. execute(ExecutionContext ec)voidProgram. execute(ExecutionContext ec)abstract voidProgramBlock. execute(ExecutionContext ec)Executes this program block (incl recompilation if required).voidWhileProgramBlock. execute(ExecutionContext ec)ScalarObjectProgramBlock. executePredicate(ArrayList<Instruction> inst, Hop hops, boolean requiresRecompile, Types.ValueType retType, ExecutionContext ec)Executes given predicate instructions (incl recompilation if required)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.controlprogram.contextSubclasses of ExecutionContext in org.apache.sysds.runtime.controlprogram.context Modifier and Type Class Description classSparkExecutionContextMethods in org.apache.sysds.runtime.controlprogram.context that return ExecutionContext Modifier and Type Method Description static ExecutionContextExecutionContextFactory. createContext()static ExecutionContextExecutionContextFactory. createContext(boolean allocateVars, boolean allocateLineage, Program prog)static ExecutionContextExecutionContextFactory. createContext(boolean allocateVars, Program prog)static ExecutionContextExecutionContextFactory. createContext(LocalVariableMap vars, Program prog)static ExecutionContextExecutionContextFactory. createContext(Program prog)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.controlprogram.federatedMethods in org.apache.sysds.runtime.controlprogram.federated that return ExecutionContext Modifier and Type Method Description ExecutionContextExecutionContextMap. get(long tid)Methods in org.apache.sysds.runtime.controlprogram.federated with parameters of type ExecutionContext Modifier and Type Method Description voidFederatedWorkloadAnalyzer. compressRun(ExecutionContext ec, long tid)FederatedResponseFederatedStatistics.FedStatsCollectFunction. execute(ExecutionContext ec, Data... data)abstract FederatedResponseFederatedUDF. execute(ExecutionContext ec, Data... data)Execute the user-defined function on a set of data objects (e.g., matrix objects, frame objects, or scalars), which are looked up by specified input IDs and passed in the same order.org.apache.commons.lang3.tuple.Pair<String,LineageItem>FederatedStatistics.FedStatsCollectFunction. getLineageItem(ExecutionContext ec)voidFederatedWorkloadAnalyzer. incrementWorkload(ExecutionContext ec, long tid, Instruction ins)voidFederatedWorkloadAnalyzer. incrementWorkload(ExecutionContext ec, ConcurrentHashMap<Long,InstructionTypeCounter> mm, ComputationCPInstruction cpIns)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.controlprogram.paramservMethods in org.apache.sysds.runtime.controlprogram.paramserv that return ExecutionContext Modifier and Type Method Description static ExecutionContextParamservUtils. createExecutionContext(ExecutionContext ec, LocalVariableMap varsMap, String updFunc, String aggFunc, int k)static ExecutionContextParamservUtils. createExecutionContext(ExecutionContext ec, LocalVariableMap varsMap, String updFunc, String aggFunc, int k, boolean forceExecTypeCP)ExecutionContextSparkPSBody. getEc()Methods in org.apache.sysds.runtime.controlprogram.paramserv that return types with arguments of type ExecutionContext Modifier and Type Method Description static List<ExecutionContext>ParamservUtils. copyExecutionContext(ExecutionContext ec, int num)Methods in org.apache.sysds.runtime.controlprogram.paramserv with parameters of type ExecutionContext Modifier and Type Method Description static voidParamservUtils. cleanupData(ExecutionContext ec, String varName)static voidParamservUtils. cleanupData(ExecutionContext ec, Data data)static voidParamservUtils. cleanupListObject(ExecutionContext ec, String lName)Clean up the list object according to its own data statusstatic voidParamservUtils. cleanupListObject(ExecutionContext ec, String lName, boolean[] status)Clean up the list object according to the given array of data status (i.e., false => not be removed)static voidParamservUtils. cleanupListObject(ExecutionContext ec, ListObject lo)static voidParamservUtils. cleanupListObject(ExecutionContext ec, ListObject lo, boolean[] status)static List<ExecutionContext>ParamservUtils. copyExecutionContext(ExecutionContext ec, int num)static HEParamServerHEParamServer. create(ListObject model, String aggFunc, Statement.PSUpdateType updateType, Statement.PSFrequency freq, ExecutionContext ec, int workerNum, String valFunc, int numBatchesPerEpoch, MatrixObject valFeatures, MatrixObject valLabels, int nbatches)static LocalParamServerLocalParamServer. create(ListObject model, String aggFunc, Statement.PSUpdateType updateType, Statement.PSFrequency freq, ExecutionContext ec, int workerNum, String valFunc, int numBatchesPerEpoch, MatrixObject valFeatures, MatrixObject valLabels, int nbatches, boolean modelAvg)static ExecutionContextParamservUtils. createExecutionContext(ExecutionContext ec, LocalVariableMap varsMap, String updFunc, String aggFunc, int k)static ExecutionContextParamservUtils. createExecutionContext(ExecutionContext ec, LocalVariableMap varsMap, String updFunc, String aggFunc, int k, boolean forceExecTypeCP)voidSparkPSBody. setEc(ExecutionContext ec)Constructors in org.apache.sysds.runtime.controlprogram.paramserv with parameters of type ExecutionContext Constructor Description FederatedPSControlThread(int workerID, String updFunc, Statement.PSFrequency freq, Statement.PSRuntimeBalancing runtimeBalancing, boolean weighting, int epochs, long batchSize, int numBatchesPerGlobalEpoch, ExecutionContext ec, ParamServer ps, int nbatches, boolean modelAvg, boolean use_homomorphic_encryption)LocalPSWorker(int workerID, String updFunc, Statement.PSFrequency freq, int epochs, long batchSize, ExecutionContext ec, ParamServer ps, int nbatches, boolean modelAvg)SparkPSBody(ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.controlprogram.parforMethods in org.apache.sysds.runtime.controlprogram.parfor that return ExecutionContext Modifier and Type Method Description ExecutionContextParForBody. getEc()ExecutionContextParWorker. getExecutionContext()Methods in org.apache.sysds.runtime.controlprogram.parfor with parameters of type ExecutionContext Modifier and Type Method Description static RemoteParForJobReturnRemoteDPParForSpark. runJob(long pfid, String itervar, String matrixvar, String program, HashMap<String,byte[]> clsMap, String resultFile, MatrixObject input, ExecutionContext ec, ParForProgramBlock.PartitionFormat dpf, Types.FileFormat fmt, boolean tSparseCol, boolean enableCPCaching, int numReducers)static RemoteParForJobReturnRemoteParForSpark. runJob(long pfid, String prog, HashMap<String,byte[]> clsMap, List<Task> tasks, ExecutionContext ec, Set<String> brVars, List<ParForStatementBlock.ResultVar> resultVars, boolean cpCaching, int numMappers, boolean topLevelPF)voidParForBody. setEc(ExecutionContext ec)Constructors in org.apache.sysds.runtime.controlprogram.parfor with parameters of type ExecutionContext Constructor Description DataPartitionerRemoteSpark(ParForProgramBlock.PartitionFormat dpf, ExecutionContext ec, long numRed, int replication, boolean keepIndexes)ParForBody(ArrayList<ProgramBlock> childBlocks, ArrayList<ParForStatementBlock.ResultVar> resultVars, ExecutionContext ec)ResultMergeRemoteSpark(MatrixObject out, MatrixObject[] in, String outputFilename, boolean accum, ExecutionContext ec, int numMappers, int numReducers)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.controlprogram.parfor.optMethods in org.apache.sysds.runtime.controlprogram.parfor.opt with parameters of type ExecutionContext Modifier and Type Method Description static OptTreeOptTreeConverter. createAbstractOptTree(int ck, double cm, ParForStatementBlock pfsb, ParForProgramBlock pfpb, OptTreePlanMappingAbstract hlMap, Set<String> memo, ExecutionContext ec)static OptTreeOptTreeConverter. createOptTree(int ck, double cm, Optimizer.PlanInputType type, ParForStatementBlock pfsb, ParForProgramBlock pfpb, ExecutionContext ec)static voidOptimizationWrapper. optimize(ParForProgramBlock.POptMode type, ParForStatementBlock sb, ParForProgramBlock pb, ExecutionContext ec, boolean monitor)Called once per top-level parfor (during runtime, on parfor execute) in order to optimize the specific parfor program block.abstract booleanOptimizer. optimize(ParForStatementBlock sb, ParForProgramBlock pb, OptTree plan, CostEstimator est, ExecutionContext ec)OptimizebooleanOptimizerConstrained. optimize(ParForStatementBlock sb, ParForProgramBlock pb, OptTree plan, CostEstimator est, ExecutionContext ec)Main optimization procedure.booleanOptimizerRuleBased. optimize(ParForStatementBlock sb, ParForProgramBlock pb, OptTree plan, CostEstimator est, ExecutionContext ec)Main optimization procedure.static voidProgramRecompiler. rFindAndRecompileIndexingHOP(StatementBlock sb, ProgramBlock pb, String var, ExecutionContext ec, boolean force)NOTE: if force is set, we set and recompile the respective indexing hops; otherwise, we release the forced exec type and recompile again.
- 
Uses of ExecutionContext in org.apache.sysds.runtime.instructionsMethods in org.apache.sysds.runtime.instructions with parameters of type ExecutionContext Modifier and Type Method Description voidInstruction. postprocessInstruction(ExecutionContext ec)This method should be used for any tear down after executing this instruction.InstructionInstruction. preprocessInstruction(ExecutionContext ec)This method should be used for any setup before executing this instruction.abstract voidInstruction. processInstruction(ExecutionContext ec)This method should be used to execute the instruction.
- 
Uses of ExecutionContext in org.apache.sysds.runtime.instructions.cpMethods in org.apache.sysds.runtime.instructions.cp with parameters of type ExecutionContext Modifier and Type Method Description org.apache.commons.lang3.tuple.Pair<String,LineageItem>ComputationCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>CtableCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>DataGenCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>FrameIndexingCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ListIndexingCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MatrixAppendCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MatrixBuiltinNaryCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MatrixIndexingCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ParameterizedBuiltinCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ReshapeCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ScalarBuiltinNaryCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>SpoofCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>StringInitCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>VariableCPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair[]MultiReturnBuiltinCPInstruction. getLineageItems(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair[]MultiReturnParameterizedBuiltinCPInstruction. getLineageItems(ExecutionContext ec)CacheableData<?>ParameterizedBuiltinCPInstruction. getTarget(ExecutionContext ec)voidCPInstruction. postprocessInstruction(ExecutionContext ec)voidFunctionCallCPInstruction. postprocessInstruction(ExecutionContext ec)InstructionCPInstruction. preprocessInstruction(ExecutionContext ec)InstructionFunctionCallCPInstruction. preprocessInstruction(ExecutionContext ec)voidDnnCPInstruction. processBatchNorm2dBackwardInstruction(ExecutionContext ec)voidDnnCPInstruction. processBatchNorm2dInstruction(ExecutionContext ec)voidDnnCPInstruction. processBiasAddInstruction(ExecutionContext ec)voidDnnCPInstruction. processBiasMultiplyInstruction(ExecutionContext ec)voidAggregateBinaryCPInstruction. processInstruction(ExecutionContext ec)voidAggregateTernaryCPInstruction. processInstruction(ExecutionContext ec)voidAggregateUnaryCPInstruction. processInstruction(ExecutionContext ec)voidBinaryFrameFrameCPInstruction. processInstruction(ExecutionContext ec)voidBinaryFrameMatrixCPInstruction. processInstruction(ExecutionContext ec)voidBinaryMatrixMatrixCPInstruction. processInstruction(ExecutionContext ec)voidBinaryMatrixScalarCPInstruction. processInstruction(ExecutionContext ec)voidBinaryScalarScalarCPInstruction. processInstruction(ExecutionContext ec)voidBinaryTensorTensorCPInstruction. processInstruction(ExecutionContext ec)voidBroadcastCPInstruction. processInstruction(ExecutionContext ec)voidCentralMomentCPInstruction. processInstruction(ExecutionContext ec)voidCompressionCPInstruction. processInstruction(ExecutionContext ec)voidCovarianceCPInstruction. processInstruction(ExecutionContext ec)abstract voidCPInstruction. processInstruction(ExecutionContext ec)voidCtableCPInstruction. processInstruction(ExecutionContext ec)voidDataGenCPInstruction. processInstruction(ExecutionContext ec)voidDeCompressionCPInstruction. processInstruction(ExecutionContext ec)voidDnnCPInstruction. processInstruction(ExecutionContext ec)voidEvalNaryCPInstruction. processInstruction(ExecutionContext ec)voidFrameAppendCPInstruction. processInstruction(ExecutionContext ec)voidFrameIndexingCPInstruction. processInstruction(ExecutionContext ec)voidFunctionCallCPInstruction. processInstruction(ExecutionContext ec)voidListAppendRemoveCPInstruction. processInstruction(ExecutionContext ec)voidListIndexingCPInstruction. processInstruction(ExecutionContext ec)voidLocalCPInstruction. processInstruction(ExecutionContext ec)voidMatrixAppendCPInstruction. processInstruction(ExecutionContext ec)voidMatrixBuiltinNaryCPInstruction. processInstruction(ExecutionContext ec)voidMatrixIndexingCPInstruction. processInstruction(ExecutionContext ec)voidMMChainCPInstruction. processInstruction(ExecutionContext ec)voidMMTSJCPInstruction. processInstruction(ExecutionContext ec)voidMultiReturnBuiltinCPInstruction. processInstruction(ExecutionContext ec)voidMultiReturnParameterizedBuiltinCPInstruction. processInstruction(ExecutionContext ec)voidParameterizedBuiltinCPInstruction. processInstruction(ExecutionContext ec)voidParamservBuiltinCPInstruction. processInstruction(ExecutionContext ec)voidPMMJCPInstruction. processInstruction(ExecutionContext ec)voidPrefetchCPInstruction. processInstruction(ExecutionContext ec)voidQuantilePickCPInstruction. processInstruction(ExecutionContext ec)voidQuantileSortCPInstruction. processInstruction(ExecutionContext ec)voidQuaternaryCPInstruction. processInstruction(ExecutionContext ec)voidReorgCPInstruction. processInstruction(ExecutionContext ec)voidReshapeCPInstruction. processInstruction(ExecutionContext ec)voidScalarAppendCPInstruction. processInstruction(ExecutionContext ec)voidScalarBuiltinNaryCPInstruction. processInstruction(ExecutionContext ec)voidSpoofCPInstruction. processInstruction(ExecutionContext ec)voidSqlCPInstruction. processInstruction(ExecutionContext ec)voidStringInitCPInstruction. processInstruction(ExecutionContext ec)voidTernaryCPInstruction. processInstruction(ExecutionContext ec)voidTernaryFrameScalarCPInstruction. processInstruction(ExecutionContext ec)voidUaggOuterChainCPInstruction. processInstruction(ExecutionContext ec)voidUnaryFrameCPInstruction. processInstruction(ExecutionContext ec)voidUnaryMatrixCPInstruction. processInstruction(ExecutionContext ec)voidUnaryScalarCPInstruction. processInstruction(ExecutionContext ec)voidVariableCPInstruction. processInstruction(ExecutionContext ec)voidDnnCPInstruction. processReluBackwardInstruction(ExecutionContext ec)static voidVariableCPInstruction. processRmvarInstruction(ExecutionContext ec, String varname)Remove variable instruction externalized as a static function in order to allow various cleanup procedures to use the same codepath as the actual rmVar instructionConstructors in org.apache.sysds.runtime.instructions.cp with parameters of type ExecutionContext Constructor Description TriggerBroadcastTask(ExecutionContext ec, MatrixObject mo)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.instructions.cpfileMethods in org.apache.sysds.runtime.instructions.cpfile with parameters of type ExecutionContext Modifier and Type Method Description voidMatrixIndexingCPFileInstruction. processInstruction(ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.instructions.fedMethods in org.apache.sysds.runtime.instructions.fed with parameters of type ExecutionContext Modifier and Type Method Description static InstructionFEDInstructionUtils. checkAndReplaceCP(Instruction inst, ExecutionContext ec)Check and replace CP instructions with federated instructions if the instruction match criteria.static InstructionFEDInstructionUtils. checkAndReplaceSP(Instruction inst, ExecutionContext ec)org.apache.sysds.runtime.instructions.fed.MultiReturnParameterizedBuiltinFEDInstruction.EncoderColnamesMultiReturnParameterizedBuiltinFEDInstruction. createGlobalEncoderWithEquiHeight(ExecutionContext ec, FrameObject fin, String spec)FederatedResponseMultiReturnParameterizedBuiltinFEDInstruction.CreateFrameEncoder. execute(ExecutionContext ec, Data... data)FederatedResponseMultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder. execute(ExecutionContext ec, Data... data)FederatedResponseParameterizedBuiltinFEDInstruction.DecodeMatrix. execute(ExecutionContext ec, Data... data)FederatedResponseQuantilePickFEDInstruction.CreateMatrixFromFrame. execute(ExecutionContext ec, Data... data)FederatedResponseQuantilePickFEDInstruction.GetHistogram. execute(ExecutionContext ec, Data... data)FederatedResponseQuantilePickFEDInstruction.GetValuesInRange. execute(ExecutionContext ec, Data... data)FederatedResponseQuantilePickFEDInstruction.GetValuesInRanges. execute(ExecutionContext ec, Data... data)FederatedResponseQuantilePickFEDInstruction.MinMax. execute(ExecutionContext ec, Data... data)FederatedResponseReorgFEDInstruction.DiagMatrix. execute(ExecutionContext ec, Data... data)FederatedResponseReorgFEDInstruction.Rdiag. execute(ExecutionContext ec, Data... data)<T> MatrixBlockQuantilePickFEDInstruction. getEquiHeightBins(ExecutionContext ec, int colID, double[] quantiles)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ComputationFEDInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>InitFEDInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MultiReturnParameterizedBuiltinFEDInstruction.CreateFrameEncoder. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MultiReturnParameterizedBuiltinFEDInstruction.ExecuteFrameEncoder. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ParameterizedBuiltinFEDInstruction.DecodeMatrix. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>QuantilePickFEDInstruction.CreateMatrixFromFrame. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>QuantilePickFEDInstruction.GetHistogram. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>QuantilePickFEDInstruction.GetValuesInRange. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>QuantilePickFEDInstruction.GetValuesInRanges. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>QuantilePickFEDInstruction.MinMax. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ReorgFEDInstruction.DiagMatrix. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ReorgFEDInstruction.Rdiag. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ReshapeFEDInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>VariableFEDInstruction. getLineageItem(ExecutionContext ec)CacheableData<?>ParameterizedBuiltinFEDInstruction. getTarget(ExecutionContext ec)static booleanSpoofFEDInstruction. isFederated(ExecutionContext ec, FTypes.FType type, CPOperand[] inputs, Class<?> scla)static booleanSpoofFEDInstruction. isFederated(ExecutionContext ec, CPOperand[] inputs, Class<?> scla)InstructionFEDInstruction. preprocessInstruction(ExecutionContext ec)voidQuantilePickFEDInstruction. processColumnQPick(ExecutionContext ec)voidQuantileSortFEDInstruction. processColumnQSort(ExecutionContext ec)voidCumulativeOffsetFEDInstruction. processCumulativeInstruction(ExecutionContext ec)voidUnaryMatrixFEDInstruction. processCumulativeInstruction(ExecutionContext ec, MatrixObject mo1)voidInitFEDInstruction. processFromLocalFedInit(ExecutionContext ec)voidAggregateBinaryFEDInstruction. processInstruction(ExecutionContext ec)voidAggregateTernaryFEDInstruction. processInstruction(ExecutionContext ec)voidAggregateUnaryFEDInstruction. processInstruction(ExecutionContext ec)voidAppendFEDInstruction. processInstruction(ExecutionContext ec)voidBinaryMatrixMatrixFEDInstruction. processInstruction(ExecutionContext ec)voidBinaryMatrixScalarFEDInstruction. processInstruction(ExecutionContext ec)voidCastFEDInstruction. processInstruction(ExecutionContext ec)voidCentralMomentFEDInstruction. processInstruction(ExecutionContext ec)voidCovarianceFEDInstruction. processInstruction(ExecutionContext ec)voidCtableFEDInstruction. processInstruction(ExecutionContext ec)voidCumulativeOffsetFEDInstruction. processInstruction(ExecutionContext ec)voidIndexingFEDInstruction. processInstruction(ExecutionContext ec)voidInitFEDInstruction. processInstruction(ExecutionContext ec)voidMMChainFEDInstruction. processInstruction(ExecutionContext ec)voidMMFEDInstruction. processInstruction(ExecutionContext ec)voidMultiReturnParameterizedBuiltinFEDInstruction. processInstruction(ExecutionContext ec)voidParameterizedBuiltinFEDInstruction. processInstruction(ExecutionContext ec)voidQuantilePickFEDInstruction. processInstruction(ExecutionContext ec)voidQuantileSortFEDInstruction. processInstruction(ExecutionContext ec)voidQuaternaryWCeMMFEDInstruction. processInstruction(ExecutionContext ec)voidQuaternaryWDivMMFEDInstruction. processInstruction(ExecutionContext ec)voidQuaternaryWSigmoidFEDInstruction. processInstruction(ExecutionContext ec)voidQuaternaryWSLossFEDInstruction. processInstruction(ExecutionContext ec)voidQuaternaryWUMMFEDInstruction. processInstruction(ExecutionContext ec)voidReblockFEDInstruction. processInstruction(ExecutionContext ec)voidReorgFEDInstruction. processInstruction(ExecutionContext ec)voidReshapeFEDInstruction. processInstruction(ExecutionContext ec)voidSpoofFEDInstruction. processInstruction(ExecutionContext ec)voidTernaryFEDInstruction. processInstruction(ExecutionContext ec)voidTernaryFrameScalarFEDInstruction. processInstruction(ExecutionContext ec)voidTsmmFEDInstruction. processInstruction(ExecutionContext ec)voidUnaryMatrixFEDInstruction. processInstruction(ExecutionContext ec)voidVariableFEDInstruction. processInstruction(ExecutionContext ec)<T> voidQuantilePickFEDInstruction. processRowQPick(ExecutionContext ec)voidQuantileSortFEDInstruction. processRowQSort(ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.instructions.gpuMethods in org.apache.sysds.runtime.instructions.gpu with parameters of type ExecutionContext Modifier and Type Method Description org.apache.commons.lang3.tuple.Pair<String,LineageItem>GPUInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MatrixIndexingGPUInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MatrixReshapeGPUInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>SpoofCUDAInstruction. getLineageItem(ExecutionContext ec)voidGPUInstruction. postprocessInstruction(ExecutionContext ec)InstructionGPUInstruction. preprocessInstruction(ExecutionContext ec)voidDnnGPUInstruction. processBatchNorm2dBackwardInstruction(ExecutionContext ec)voidAggregateBinaryGPUInstruction. processInstruction(ExecutionContext ec)voidAggregateUnaryGPUInstruction. processInstruction(ExecutionContext ec)voidDnnGPUInstruction. processInstruction(ExecutionContext ec)abstract voidGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixAppendGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixBuiltinGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixIndexingGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixMatrixArithmeticGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixMatrixAxpyGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixMatrixBuiltinGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixMatrixRelationalBinaryGPUInstruction. processInstruction(ExecutionContext ec)voidMatrixReshapeGPUInstruction. processInstruction(ExecutionContext ec)voidMMTSJGPUInstruction. processInstruction(ExecutionContext ec)voidReorgGPUInstruction. processInstruction(ExecutionContext ec)voidScalarMatrixArithmeticGPUInstruction. processInstruction(ExecutionContext ec)voidScalarMatrixBuiltinGPUInstruction. processInstruction(ExecutionContext ec)voidScalarMatrixRelationalBinaryGPUInstruction. processInstruction(ExecutionContext ec)voidSpoofCUDAInstruction. processInstruction(ExecutionContext ec)voidDnnGPUInstruction. processReLUBackwardInstruction(ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.instructions.sparkMethods in org.apache.sysds.runtime.instructions.spark with parameters of type ExecutionContext Modifier and Type Method Description org.apache.commons.lang3.tuple.Pair<String,LineageItem>BuiltinNarySPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ComputationSPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>MatrixIndexingSPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>RandSPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>ReblockSPInstruction. getLineageItem(ExecutionContext ec)org.apache.commons.lang3.tuple.Pair<String,LineageItem>WriteSPInstruction. getLineageItem(ExecutionContext ec)CacheableData<?>ParameterizedBuiltinSPInstruction. getTarget(ExecutionContext ec)voidSPInstruction. postprocessInstruction(ExecutionContext ec)InstructionSPInstruction. preprocessInstruction(ExecutionContext ec)voidAggregateTernarySPInstruction. processInstruction(ExecutionContext ec)voidAggregateUnarySketchSPInstruction. processInstruction(ExecutionContext ec)voidAggregateUnarySPInstruction. processInstruction(ExecutionContext ec)voidAppendGAlignedSPInstruction. processInstruction(ExecutionContext ec)voidAppendGSPInstruction. processInstruction(ExecutionContext ec)voidBinaryFrameFrameSPInstruction. processInstruction(ExecutionContext ec)voidBinaryFrameMatrixSPInstruction. processInstruction(ExecutionContext ec)voidBinaryMatrixBVectorSPInstruction. processInstruction(ExecutionContext ec)voidBinaryMatrixMatrixSPInstruction. processInstruction(ExecutionContext ec)voidBinaryMatrixScalarSPInstruction. processInstruction(ExecutionContext ec)voidBinaryTensorTensorBroadcastSPInstruction. processInstruction(ExecutionContext ec)voidBinaryTensorTensorSPInstruction. processInstruction(ExecutionContext ec)voidBinUaggChainSPInstruction. processInstruction(ExecutionContext ec)voidBuiltinNarySPInstruction. processInstruction(ExecutionContext ec)voidCastSPInstruction. processInstruction(ExecutionContext ec)voidCentralMomentSPInstruction. processInstruction(ExecutionContext ec)voidCheckpointSPInstruction. processInstruction(ExecutionContext ec)voidCompressionSPInstruction. processInstruction(ExecutionContext ec)voidCovarianceSPInstruction. processInstruction(ExecutionContext ec)voidCpmmSPInstruction. processInstruction(ExecutionContext ec)voidCSVReblockSPInstruction. processInstruction(ExecutionContext ec)voidCtableSPInstruction. processInstruction(ExecutionContext ec)voidCumulativeAggregateSPInstruction. processInstruction(ExecutionContext ec)voidCumulativeOffsetSPInstruction. processInstruction(ExecutionContext ec)voidDeCompressionSPInstruction. processInstruction(ExecutionContext ec)voidDnnSPInstruction. processInstruction(ExecutionContext ec)voidFrameAppendMSPInstruction. processInstruction(ExecutionContext ec)voidFrameAppendRSPInstruction. processInstruction(ExecutionContext ec)voidFrameIndexingSPInstruction. processInstruction(ExecutionContext ec)voidLIBSVMReblockSPInstruction. processInstruction(ExecutionContext ec)voidMapmmChainSPInstruction. processInstruction(ExecutionContext ec)voidMapmmSPInstruction. processInstruction(ExecutionContext ec)voidMatrixAppendMSPInstruction. processInstruction(ExecutionContext ec)voidMatrixAppendRSPInstruction. processInstruction(ExecutionContext ec)voidMatrixIndexingSPInstruction. processInstruction(ExecutionContext ec)voidMatrixReshapeSPInstruction. processInstruction(ExecutionContext ec)voidMultiReturnParameterizedBuiltinSPInstruction. processInstruction(ExecutionContext ec)voidParameterizedBuiltinSPInstruction. processInstruction(ExecutionContext ec)voidPMapmmSPInstruction. processInstruction(ExecutionContext ec)voidPmmSPInstruction. processInstruction(ExecutionContext ec)voidQuantilePickSPInstruction. processInstruction(ExecutionContext ec)voidQuantileSortSPInstruction. processInstruction(ExecutionContext ec)voidQuaternarySPInstruction. processInstruction(ExecutionContext ec)voidRandSPInstruction. processInstruction(ExecutionContext ec)voidReblockSPInstruction. processInstruction(ExecutionContext ec)voidReorgSPInstruction. processInstruction(ExecutionContext ec)voidRmmSPInstruction. processInstruction(ExecutionContext ec)abstract voidSPInstruction. processInstruction(ExecutionContext ec)voidSpoofSPInstruction. processInstruction(ExecutionContext ec)voidTernaryFrameScalarSPInstruction. processInstruction(ExecutionContext ec)voidTernarySPInstruction. processInstruction(ExecutionContext ec)voidTsmm2SPInstruction. processInstruction(ExecutionContext ec)voidTsmmSPInstruction. processInstruction(ExecutionContext ec)voidUaggOuterChainSPInstruction. processInstruction(ExecutionContext ec)voidUnaryFrameSPInstruction. processInstruction(ExecutionContext ec)voidUnaryMatrixSPInstruction. processInstruction(ExecutionContext ec)voidWriteSPInstruction. processInstruction(ExecutionContext ec)voidZipmmSPInstruction. processInstruction(ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.instructions.spark.utilsMethods in org.apache.sysds.runtime.instructions.spark.utils with parameters of type ExecutionContext Modifier and Type Method Description static voidSparkUtils. checkSparsity(String varname, ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.lineageMethods in org.apache.sysds.runtime.lineage with parameters of type ExecutionContext Modifier and Type Method Description static voidLineageItemUtils. addAllDataLineage(ExecutionContext ec)static LineageDedupBlockLineageDedupUtils. computeDedupBlock(ProgramBlock fpb, ExecutionContext ec)static longLineageDedupUtils. computeNumPaths(ProgramBlock fpb, ExecutionContext ec)voidLineage. createDedupPatch(ProgramBlock pb, ExecutionContext ec)static booleanLineageRewriteReuse. executeRewrites(Instruction curr, ExecutionContext ec)static LineageItem[]LineageItemUtils. getLineage(ExecutionContext ec, CPOperand... operands)org.apache.commons.lang3.tuple.Pair<String,LineageItem>LineageTraceable. getLineageItem(ExecutionContext ec)Obtain lineage trace of an instruction with a single output.static LineageItem[]LineageItemUtils. getLineageItemInputstoSB(ArrayList<String> inputs, ExecutionContext ec)default org.apache.commons.lang3.tuple.Pair<String,LineageItem>[]LineageTraceable. getLineageItems(ExecutionContext ec)Obtain lineage trace of an instruction with multiple outputs.voidLineage. initializeDedupBlock(ProgramBlock pb, ExecutionContext ec)static LineageDedupBlockLineageDedupUtils. initializeDedupBlock(ProgramBlock fpb, ExecutionContext ec)static booleanLineageCacheConfig. isReusable(Instruction inst, ExecutionContext ec)static voidLineageDebugger. maintainSpecialValueBits(Lineage lineage, Instruction inst, ExecutionContext ec)static StringLineageDedupUtils. mergeExplainDedupBlocks(ExecutionContext ec)static longLineageDedupUtils. numPathsInPBs(ArrayList<ProgramBlock> pbs, ExecutionContext ec)static voidLineageEstimator. processFunc(List<DataIdentifier> outputs, LineageItem[] liInputs, String name, ExecutionContext ec, long computetime)static voidLineageEstimator. processSingleInst(Instruction inst, ExecutionContext ec, long starttime)static voidLineageCache. putFedReadObject(Data data, LineageItem li, ExecutionContext ec)static voidLineageCache. putMatrix(Instruction inst, ExecutionContext ec, long computetime)static voidLineageCache. putValue(List<DataIdentifier> outputs, LineageItem[] liInputs, String name, ExecutionContext ec, long computetime)static voidLineageCache. putValue(FederatedUDF udf, ExecutionContext ec, long computetime)static voidLineageCache. putValue(Instruction inst, ExecutionContext ec, long starttime)static voidLineageItemUtils. replaceDagLeaves(ExecutionContext ec, LineageItem root, CPOperand[] newLeaves)static voidLineageDedupUtils. replaceLineage(ExecutionContext ec)static booleanLineageCache. reuse(List<String> outNames, List<DataIdentifier> outParams, int numOutputs, LineageItem[] liInputs, String name, ExecutionContext ec)static FederatedResponseLineageCache. reuse(FederatedUDF udf, ExecutionContext ec)static booleanLineageCache. reuse(Instruction inst, ExecutionContext ec)static booleanLineageCache. reuseFedRead(String outName, Types.DataType dataType, LineageItem li, ExecutionContext ec)static voidLineageDedupUtils. setNewDedupPatch(LineageDedupBlock ldb, ProgramBlock fpb, ExecutionContext ec)voidLineageDedupBlock. setNumPathsInPBs(ArrayList<ProgramBlock> pbs, ExecutionContext ec)voidLineage. trace(Instruction inst, ExecutionContext ec)voidLineageMap. trace(Instruction inst, ExecutionContext ec)voidLineageDedupBlock. traceBasicProgramBlock(BasicProgramBlock bpb, ExecutionContext ec, Collection<Map.Entry<Long,LineageMap>> paths)voidLineage. traceCurrentDedupPath(ProgramBlock pb, ExecutionContext ec)static voidLineageItemUtils. traceFedUDF(ExecutionContext ec, FederatedUDF udf)voidLineageDedupBlock. traceIfProgramBlock(IfProgramBlock ipb, ExecutionContext ec, Collection<Map.Entry<Long,LineageMap>> paths)voidLineageDedupBlock. traceProgramBlock(ProgramBlock pb, ExecutionContext ec, Collection<Map.Entry<Long,LineageMap>> paths)voidLineageDedupBlock. traceProgramBlocks(ArrayList<ProgramBlock> pbs, ExecutionContext ec)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.matrix.dataMethods in org.apache.sysds.runtime.matrix.data with parameters of type ExecutionContext Modifier and Type Method Description static voidLibMatrixCUDA. abs(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "abs" operation on a matrix on the GPUstatic voidLibMatrixCUDA. acos(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "acos" operation on a matrix on the GPUstatic voidLibMatrixCUDA. asin(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "asin" operation on a matrix on the GPUstatic voidLibMatrixCUDA. atan(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "atan" operation on a matrix on the GPUstatic voidLibMatrixCUDA. axpy(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, MatrixObject in2, String outputName, double constant)Performs daxpy operationstatic voidLibMatrixCUDA. cbind(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, MatrixObject in2, String outputName)static voidLibMatrixCUDA. ceil(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "ceil" operation on a matrix on the GPUstatic voidLibMatrixCUDA. cos(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "cos" operation on a matrix on the GPUstatic voidLibMatrixCUDA. cosh(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "cosh" operation on a matrix on the GPUstatic voidLibMatrixCUDA. cumulativeScan(ExecutionContext ec, GPUContext gCtx, String instName, String kernelFunction, MatrixObject in, String outputName)Cumulative scanstatic voidLibMatrixCUDA. cumulativeSumProduct(ExecutionContext ec, GPUContext gCtx, String instName, String kernelFunction, MatrixObject in, String outputName)Cumulative sum-product kernel cascade invokationstatic voidLibMatrixCUDA. denseTranspose(ExecutionContext ec, GPUContext gCtx, String instName, jcuda.Pointer A, jcuda.Pointer C, long numRowsA, long numColsA)Computes C = t(A)static voidLibMatrixCUDA. exp(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "exp" operation on a matrix on the GPUstatic voidLibMatrixCUDA. floor(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "floor" operation on a matrix on the GPUstatic MatrixObjectLibMatrixCUDA. getDenseMatrixOutputForGPUInstruction(ExecutionContext ec, String instName, String name, long numRows, long numCols)Helper method to get the output block (allocated on the GPU) Also records performance information intoStatisticsstatic MatrixObjectLibMatrixCUDA. getDenseMatrixOutputForGPUInstruction(ExecutionContext ec, String instName, String name, long numRows, long numCols, boolean initialize)static voidLibMatrixCUDA. log(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "log" operation on a matrix on the GPUstatic voidLibMatrixCuDNN. lstm(ExecutionContext ec, GPUContext gCtx, String instName, jcuda.Pointer X, jcuda.Pointer wPointer, jcuda.Pointer out0, jcuda.Pointer c0, boolean return_sequences, String outputName, String cyName, int N, int M, int D, int T)Computes the forward pass for an LSTM layer with M neurons.static voidLibMatrixCuDNN. lstmBackward(ExecutionContext ec, GPUContext gCtx, String instName, jcuda.Pointer x, jcuda.Pointer hx, jcuda.Pointer cx, jcuda.Pointer wPointer, String doutName, String dcyName, String dxName, String dwName, String dbName, String dhxName, String dcxName, boolean return_sequences, int N, int M, int D, int T)static MatrixObjectLibMatrixCuMatMult. matmult(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject left, MatrixObject right, String outputName, boolean isLeftTransposed, boolean isRightTransposed)Matrix multiply on GPU Examines sparsity and shapes and routes call to appropriate method from cuBLAS or cuSparse C = op(A) x op(B) The user is expected to call ec.releaseMatrixOutputForGPUInstruction(outputName);static voidLibMatrixCUDA. matmultTSMM(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject left, String outputName, boolean isLeftTransposed)Performs tsmm, A %*% A' or A' %*% A, on GPU by exploiting cublasDsyrk(...)static voidLibMatrixCUDA. matrixMatrixArithmetic(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, MatrixObject in2, String outputName, boolean isLeftTransposed, boolean isRightTransposed, BinaryOperator op)Performs elementwise arithmetic operation specified by op of two input matrices in1 and in2static voidLibMatrixCUDA. matrixMatrixRelational(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, MatrixObject in2, String outputName, BinaryOperator op)Performs elementwise operation relational specified by op of two input matrices in1 and in2static voidLibMatrixCUDA. matrixScalarArithmetic(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in, String outputName, boolean isInputTransposed, ScalarOperator op)Entry point to perform elementwise matrix-scalar arithmetic operation specified by opstatic voidLibMatrixCUDA. matrixScalarOp(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in, String outputName, boolean isInputTransposed, ScalarOperator op)Utility to do matrix-scalar operation kernelstatic voidLibMatrixCUDA. matrixScalarRelational(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in, String outputName, ScalarOperator op)Entry point to perform elementwise matrix-scalar relational operation specified by opstatic voidLibMatrixCUDA. rbind(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, MatrixObject in2, String outputName)static voidLibMatrixCuDNN. relu(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in, String outputName)Performs the relu operation on the GPU.static voidLibMatrixCUDA. round(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "round" operation on a matrix on the GPUstatic voidLibMatrixCUDA. sigmoid(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "sigmoid" operation on a matrix on the GPUstatic voidLibMatrixCUDA. sign(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "sign" operation on a matrix on the GPUstatic voidLibMatrixCUDA. sin(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "sin" operation on a matrix on the GPUstatic voidLibMatrixCUDA. sinh(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "sinh" operation on a matrix on the GPUstatic voidLibMatrixCUDA. sliceOperations(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, IndexRange ixrange, String outputName)Method to perform rightIndex operation for a given lower and upper bounds in row and column dimensions.static voidLibMatrixCuDNN. softmax(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "softmax" operation on a matrix on the GPUstatic voidLibMatrixCUDA. solve(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, MatrixObject in2, String outputName)Implements the "solve" function for systemds Ax = B (A is of size m*n, B is of size m*1, x is of size n*1)static voidLibMatrixCUDA. sqrt(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "sqrt" operation on a matrix on the GPUstatic voidLibMatrixCUDA. tan(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "tan" operation on a matrix on the GPUstatic voidLibMatrixCUDA. tanh(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String outputName)Performs an "tanh" operation on a matrix on the GPUstatic voidLibMatrixCUDA. transpose(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in, String outputName)Transposes the input matrix using cublasDgeamstatic voidLibMatrixCUDA. unaryAggregate(ExecutionContext ec, GPUContext gCtx, String instName, MatrixObject in1, String output, AggregateUnaryOperator op)Entry point to perform Unary aggregate operations on the GPU.Constructors in org.apache.sysds.runtime.matrix.data with parameters of type ExecutionContext Constructor Description LibMatrixCuDNNRnnAlgorithm(ExecutionContext ec, GPUContext gCtx, String instName, String rnnMode, int N, int T, int M, int D, boolean isTraining, jcuda.Pointer w)
- 
Uses of ExecutionContext in org.apache.sysds.runtime.privacy.propagationMethods in org.apache.sysds.runtime.privacy.propagation with parameters of type ExecutionContext Modifier and Type Method Description static OperatorTypeOperatorType. getAggregationType(AggregateBinaryCPInstruction inst, ExecutionContext ec)Returns the operator type of AggregateBinaryCPInstruction based on the input data characteristics and the transpose.static OperatorTypeOperatorType. getAggregationType(MMChainCPInstruction inst, ExecutionContext ec)Returns the operator type of MMChainCPInstruction based on the input data characteristics.static OperatorTypeOperatorType. getAggregationType(MMTSJCPInstruction inst, ExecutionContext ec)Returns the operator type of MMTSJCPInstruction based on the input data characteristics and the MMTSJType.static voidPrivacyPropagator. postProcessInstruction(Instruction inst, ExecutionContext ec)Propagate privacy constraints to output variables based on privacy constraint of CPOperand output in instruction which has been set during privacy propagation preprocessing.static InstructionPrivacyPropagator. preprocessInstruction(Instruction inst, ExecutionContext ec)Propagate privacy constraints from input to output CPOperands in case the privacy constraints of the input are activated.
- 
Uses of ExecutionContext in org.apache.sysds.runtime.utilMethods in org.apache.sysds.runtime.util that return ExecutionContext Modifier and Type Method Description static ExecutionContextProgramConverter. createDeepCopyExecutionContext(ExecutionContext ec)Creates a deep copy of the given execution context.Methods in org.apache.sysds.runtime.util with parameters of type ExecutionContext Modifier and Type Method Description static ExecutionContextProgramConverter. createDeepCopyExecutionContext(ExecutionContext ec)Creates a deep copy of the given execution context.static ListObjectAutoDiff. getBackward(MatrixObject mo, ArrayList<Data> lineage, ExecutionContext adec)static int[]DataConverter. getTensorDimensions(ExecutionContext ec, CPOperand dims)static List<Data>AutoDiff. parseNComputeAutoDiffFromLineage(MatrixObject mo, String mainTrace, ArrayList<String> names, ExecutionContext ec)
 
-