-
Notifications
You must be signed in to change notification settings - Fork 26
Server implementation scorecard
Classes/Files to implement, X indicates implemented
This list of classes is generated by analyzing the dependencies of the spark examples and bringing in all references. This is done so that Spark implementation classes are not included, only API level classes.
The implemented numbers are programatically generated, and are not completely accurate, for instance when a implemented function name does not match the generated name, or where the function does not make sense to implement in javascript.
Number of classes: 92
Number of functions: 1291
Number of implemented classes: 132
Number of implemented functions (exact name match): 517
Number of total implemented functions: 1591
-
Accumulable.js
- add X
- localValue X
- merge X
- setValue X
- toString X
- value X
- value_$eq
-
AccumulableParam.js
- addAccumulator X
- addInPlace X
- zero X
-
Accumulator.js
-
AccumulatorParam.js
- addAccumulator X
-
FutureAction.js
- cancel X
- get X
- isCancelled X
- isCompleted
- jobIds X
- onComplete
- ready
- result
- value
-
Logging.js
-
PairRDD.js
- aggregateByKey
- cache X
- coalesce X
- cogroup
- collectAsMap X
- combineByKey
- countApproxDistinctByKey
- countByKey X
- countByKeyApprox X
- distinct X
- filter X
- first X
- flatMapValues X
- foldByKey
- fullOuterJoin
- groupByKey X
- groupWith
- intersection X
- join X
- keys X
- leftOuterJoin
- lookup X
- mapValues X
- partitionBy X
- persist X
- reduceByKey X
- reduceByKeyLocally X
- repartition X
- repartitionAndSortWithinPartitions X
- rightOuterJoin
- sample X
- sampleByKey X
- sampleByKeyExact X
- saveAsHadoopDataset X
- saveAsHadoopFile
- saveAsNewAPIHadoopDataset X
- saveAsNewAPIHadoopFile X
- saveAsNewAPIHadoopFilewithConf X
- setName X
- sortByKey
- subtract
- subtractByKey
- union X
- unpersist X
- values X
- wrapRDD X
-
Partition.js
- hashCode
- index
-
Partitioner.js
- getPartition X
- numPartitions X
-
RDD.js
- cache X
- coalesce X
- distinct X
- filter X
- intersection X
- persist X
- randomSplit X
- repartition X
- sample X
- setName X
- sortBy X
- subtract X
- toString X
- union X
- unpersist X
- wrapRDD
-
SimpleFutureAction.js
- cancel
- isCancelled
- isCompleted
- jobIds
- onComplete
- ready
- result
- value
-
SparkConf.js
- clone
- contains
- get
- getAkkaConf
- getAll
- getAppId
- getAvroSchema
- getBoolean
- getDouble
- getExecutorEnv
- getInt
- getLong
- getOption
- getSizeAsBytes
- getSizeAsGb
- getSizeAsKb
- getSizeAsMb
- getTimeAsMs
- getTimeAsSeconds
- registerAvroSchemas
- registerKryoClasses
- remove
- set
- setAll
- setAppName X
- setExecutorEnv
- setIfMissing
- setJarswithstring[]
- setMaster X
- setSparkHome
- toDebugString
-
SparkContext.js
- accumulable X
- accumulablewithParam
- accumulator X
- addFile X
- addJar X
- appName X
- binaryFiles
- binaryRecords
- broadcast X
- cancelAllJobs
- cancelJobGroup
- clearCallSite
- clearFiles
- clearJars
- clearJobGroup X
- close
- defaultMinPartitions
- defaultParallelism
- doubleAccumulator
- emptyRDD
- getCheckpointDir
- getConf X
- getLocalProperty X
- getSparkHome
- hadoopConfiguration
- hadoopFile
- hadoopRDD
- intAccumulator X
- isLocal X
- jars X
- master X
- newAPIHadoopFile
- newAPIHadoopRDD
- objectFile
- parallelize X
- parallelizeDoubles
- parallelizePairs X
- sequenceFile
- setCallSite
- setCheckpointDir X
- setJobGroup X
- setLocalProperty X
- setLogLevel X
- sparkUser
- startTime
- statusTracker X
- stop X
- textFile X
- union
- version X
- wholeTextFiles X
-
SparkStatusTracker.js
- getActiveJobIds X
- getActiveStageIds X
- getJobIdsForGroup X
- getJobInfo X
- getStageInfo X
-
TaskContext.js
- addOnCompleteCallback
- addTaskCompletionListenerwithTaskCompletionListener
- addTaskCompletionListenerwithfunc
- attemptId
- attemptNumber
- isCompleted
- isInterrupted
- isRunningLocally
- partitionId
- runningLocally
- stageId
- taskAttemptId
-
broadcast/Broadcast.js
- destroy
- toString
- unpersist
- value
-
ml/Pipeline.js
- copy
- fit
- getStages
- setStages
- transformSchema
- validateParams
- write
-
ml/PipelineModel.js
- copy
- transform
- transformSchema
- validateParams
- write
-
ml/classification/LogisticRegression.js
- copy
- getThreshold
- getThresholds
- setElasticNetParam
- setFitIntercept
- setMaxIter
- setRegParam
- setStandardization
- setThreshold
- setThresholds
- setTol
- setWeightCol
-
ml/evaluation/BinaryClassificationEvaluator.js
- copy
- evaluate
- getMetricName
- isLargerBetter
- setLabelCol
- setMetricName
- setRawPredictionCol
-
ml/feature/CountVectorizer.js
- copy
- fit
- setInputCol
- setMinDF
- setMinTF
- setOutputCol
- setVocabSize
- transformSchema
-
ml/feature/CountVectorizerModel.js
- copy
- setInputCol
- setMinTF
- setOutputCol
- transform
- transformSchema
- write
-
ml/feature/Tokenizer.js
- copy
-
ml/param/ParamMap.js
- apply
- contains
- copy
- filter
- get
- getOrElse
- put
- putwithValue
- remove
- size
- toSeq
- toString
-
ml/param/ParamPair.js
-
ml/tuning/CrossValidator.js
- copy
- fit
- setEstimator
- setEstimatorParamMaps
- setEvaluator
- setNumFolds
- transformSchema
- validateParams
- write
-
ml/tuning/CrossValidatorModel.js
- copy
- transform
- transformSchema
- validateParams
- write
-
ml/tuning/ParamGridBuilder.js
- addGrid
- baseOnwithParamMap
- baseOnwithParamPair
- build
-
ml/util/MLWritable.js
- save
- write
-
ml/util/MLWriter.js
- context
- overwrite
- save
-
mllib/clustering/KMeans.js
- getEpsilon X
- getInitializationMode X
- getInitializationSteps X
- getK X
- getMaxIterations X
- getRuns X
- getSeed X
- run X
- setEpsilon X
- setInitialModel X
- setInitializationMode X
- setInitializationSteps X
- setK X
- setMaxIterations X
- setRuns X
- setSeed X
-
mllib/clustering/KMeansModel.js
- computeCost X
- k X
- predict
- save X
-
mllib/feature/HashingTF.js
- indexOf
- transform
-
mllib/feature/IDF.js
- fitwithJavaRDD
- fitwithRDD
-
mllib/feature/IDFModel.js
- transform
-
mllib/feature/Word2Vec.js
- fitwithJavaRDD
- fitwithRDD
- setLearningRate X
- setMinCount X
- setNumIterations X
- setNumPartitions X
- setSeed X
- setVectorSize X
- setWindowSize X
-
mllib/feature/Word2VecModel.js
- findSynonymswithnumber X
- getVectors X
- save X
- transform X
-
mllib/fpm/FPGrowth.js
- runwithJavaRDD
- runwithRDD
- setMinSupport X
- setNumPartitions X
-
mllib/fpm/FPGrowthModel.js
- generateAssociationRules X
-
mllib/linalg/DenseVector.js
- apply
- argmax
- copy
- foreachActive
- hashCode
- numActives
- numNonzeros
- size
- toArray
- toJson
- toSparse
- toString
-
mllib/linalg/SparseVector.js
- argmax
- copy
- foreachActive
- hashCode
- numActives
- numNonzeros
- toArray
- toJson
- toSparse
- toString
-
mllib/linalg/Vector.js
- apply X
- argmax X
- compressed X
- copy X
- equals X
- foreachActive X
- hashCode X
- numActives X
- numNonzeros X
- size X
- toArray X
- toDense X
- toJson
- toSparse X
-
mllib/recommendation/ALS_static.js
- train
- trainImplicit
-
mllib/recommendation/MatrixFactorizationModel.js
- predict X
- recommendProducts X
- recommendProductsForUsers X
- recommendUsers X
- recommendUsersForProducts X
- save X
-
mllib/recommendation/Rating.js
-
mllib/tree/DecisionTree_static.js
- train
- trainClassifierwithnumber
- trainRegressorwithnumber
-
mllib/tree/configuration/Strategy.js
- copy X
- isMulticlassClassification X
- isMulticlassWithCategoricalFeatures X
- setAlgo X
- setCategoricalFeaturesInfo X
-
mllib/tree/impurity/Impurity.js
-
mllib/tree/model/DecisionTreeModel.js
- depth X
- numNodes X
- predict X
- save X
- toDebugString X
- toString X
-
partial/PartialResult.js
- getFinalValue X
- initialValue X
- isInitialValueFinal X
- map X
- onComplete X
- onFail X
- toString X
-
rdd/RDD.js
- aggregate X
- cache X
- cartesian X
- checkpoint X
- coalesce X
- collect X
- context X
- count X
- countApprox X
- countApproxDistinct X
- countApproxDistinctwithSp X
- countByValue X
- countByValueApprox X
- dependencies X
- distinct X
- filter X
- filterWith X
- first X
- flatMap X
- flatMapWith X
- fold X
- foreach X
- foreachPartition X
- foreachWith X
- getCheckpointFile X
- getNumPartitions
- getStorageLevel X
- glom X
- groupBy X
- intersection X
- isCheckpointed X
- isEmpty X
- iterator
- keyBy X
- localCheckpoint X
- map X
- mapPartitions X
- mapPartitionsWithIndex X
- mapPartitionsWithSplit X
- mapWith X
- max X
- min X
- partitions
- persist X
- pipe X
- preferredLocations X
- randomSplit X
- reduce X
- repartition X
- sample X
- saveAsObjectFile X
- saveAsTextFile X
- setName X
- sortBy X
- sparkContext X
- subtract X
- take X
- takeOrdered X
- takeSample X
- toArray X
- toDebugString X
- toJavaRDD
- toLocalIterator
- toString X
- top X
- treeAggregate X
- treeReduce X
- union X
- unpersist X
- zip X
- zipPartitions X
- zipWithIndex X
- zipWithUniqueId X
-
sql/Column.js
- alias X
- and X
- apply X
- as X
- asc X
- between X
- bitwiseAND X
- bitwiseOR X
- bitwiseXOR X
- castwithDataType
- castwithstring
- contains X
- desc X
- divide X
- endsWithwithColumn
- endsWithwithstring
- eqNullSafe X
- equalTo X
- equals X
- explain X
- geq X
- getField X
- getItem X
- gt X
- hashCode X
- isNaN X
- isNotNull X
- isNull X
- isin X
- leq X
- like X
- lt X
- minus X
- mod X
- multiply X
- notEqual X
- or X
- otherwise X
- over
- plus
- rlike
- startsWithwithColumn
- startsWithwithstring
- substrwithColumn
- substrwithnumber
- toString
- unary_$bang
- unary_$minus
- when X
-
sql/DataFrame.js
- agg X
- aliaswithSymbol
- aliaswithstring
- apply X
- as X
- cache X
- coalesce X
- col X
- collect X
- collectAsList
- columns X
- count X
- cube X
- cubewithCols
- describe X
- distinct X
- dropDuplicates X
- dropwithColumn
- dropwithstring
- dtypes X
- except X
- explain X
- explode
- explodewithF
- filterwithColumn
- filterwithstring
- first X
- flatMap X
- foreach X
- foreachPartition X
- groupBy X
- groupBywithCols
- head X
- inputFiles X
- intersect X
- isLocal X
- javaRDD
- join X
- limit X
- map X
- mapPartitions X
- na X
- orderBy X
- orderBywithSortCols
- persist X
- printSchema X
- randomSplit X
- registerTempTable X
- repartition X
- rollup X
- rollupwithCols
- sample X
- schema X
- select X
- selectExpr X
- selectwithCols
- show X
- sort X
- sortWithinPartitions
- sortWithinPartitionswithSortCols
- sortwithSortCols
- stat X
- take X
- takeAsList
- toDF X
- toJSON X
- toJavaRDD
- transform
- unionAll X
- unpersist X
- wherewithColumn
- wherewithstring
- withColumn X
- withColumnRenamed X
- write X
-
sql/DataFrameNaFunctions.js
- drop X
- fill X
- replace X
-
sql/DataFrameReader.js
- format X
- jdbc X
- json X
- load X
- option X
- optionswithMap
- orc X
- parquet X
- schema X
- table X
- text X
-
sql/DataFrameStatFunctions.js
- corr X
- cov X
- crosstab X
- freqItems X
- sampleBywithnumber
-
sql/DataFrameWriter.js
- format X
- insertInto X
- jdbc X
- json X
- modewithSaveMode
- modewithstring
- option X
- optionswithMap
- orc X
- parquet X
- partitionBy X
- save
- saveAsTable X
- text X
-
sql/Dataset.js
- as
- cache
- coalesce
- collect
- collectAsList
- count
- distinct
- explain
- filterwithFilterFunction
- filterwithfunc
- first
- flatMap
- flatMapwithEncoder
- foreachPartitionwithForeachPartitionFunction
- foreachPartitionwithfunc
- foreachwithForeachFunction
- foreachwithfunc
- groupBy
- intersect
- joinWith
- map
- mapPartitions
- mapPartitionswithEncoder
- mapwithEncoder
- persist
- printSchema
- rdd
- reducewithReduceFunction
- reducewithfunc
- repartition
- sample
- schema
- select
- show
- subtract
- take
- takeAsList
- toDF
- toDS
- transform
- union
- unpersist
-
sql/Encoder.js
- clsTag
- schema
-
sql/GroupedData.js
- agg X
- avg X
- count X
- max X
- mean X
- min X
- pivot X
- sum X
-
sql/GroupedDataset.js
- agg
- cogroup
- cogroupwithEncoder
- count
- flatMapGroups
- flatMapGroupswithEncoder
- keyAs
- keys
- mapGroups
- mapGroupswithEncoder
- reducewithReduceFunction
- reducewithfunc
-
sql/Row.js
- anyNull X
- apply X
- copy X
- equals X
- fieldIndex X
- get X
- getAswithnumber
- getAswithstring
- getBoolean X
- getByte X
- getDate X
- getDecimal X
- getDouble X
- getFloat X
- getInt X
- getJavaMap
- getList X
- getLong X
- getMap
- getSeq
- getShort X
- getString X
- getStruct X
- getTimestamp X
- getValuesMap
- hashCode X
- isNullAt X
- length X
- mkString X
- schema X
- size X
- toSeq
- toString X
-
sql/SQLContext.js
- baseRelationToDataFrame X
- cacheTable X
- clearCache X
- createDataFrame X
- createDataset
- createExternalTable X
- dropTempTable X
- getAllConfs X
- getConf X
- isCached X
- newSession X
- range X
- read X
- setConf X
- setConfwithValue
- sql X
- table X
- tableNames X
- tables X
- uncacheTable X
-
sql/TypedColumn.js
-
sql/catalyst/analysis/TypeCheckResult.js
- isFailure
- isSuccess
-
sql/catalyst/encoders/ExpressionEncoder.js
- assertUnresolved
- bind
- fromRow
- resolve
- shift
- toRow
- toString
-
sql/catalyst/expressions/Attribute.js
- newInstance
- references
- toAttribute
- withName
- withNullability
- withQualifiers
-
sql/catalyst/expressions/AttributeSet.js
- contains
- equals
- filter
- foreach
- intersect
- isEmpty
- iterator
- subsetOf
- toSeq
- toString
-
sql/catalyst/expressions/ExprId.js
-
sql/catalyst/expressions/Expression.js
- checkInputDataTypes
- childrenResolved
- dataType
- deterministic
- eval
- foldable
- gen
- nullable
- prettyName
- prettyString
- references
- semanticEquals
- semanticHash
- simpleString
- toString
-
sql/catalyst/expressions/LeafExpression.js
- children
-
sql/catalyst/expressions/NamedExpression.js
- exprId
- foldable
- metadata
- name
- qualifiedName
- qualifiers
- toAttribute
-
sql/catalyst/expressions/WindowSpec.js
-
sql/catalyst/expressions/codegen/CodeGenContext.js
- addMutableState
- addNewFunction
- boxedTypewithDataType
- boxedTypewithstring
- defaultValuewithDataType
- defaultValuewithstring
- freshName
- genComp
- genEqual
- genGreater
- generateExpressions
- getValue
- isPrimitiveTypewithDataType
- isPrimitiveTypewithstring
- javaType
- primitiveTypeNamewithDataType
- primitiveTypeNamewithstring
- setColumn
- splitExpressions
-
sql/catalyst/expressions/codegen/GeneratedExpressionCode.js
-
sql/catalyst/plans/QueryPlan.js
- expressions
- inputSet
- missingInput
- output
- outputSet
- printSchema
- references
- schemaString
- simpleString
- transformAllExpressions
- transformExpressions
- transformExpressionsDown
- transformExpressionsUp
-
sql/catalyst/plans/logical/LogicalPlan.js
- analyzed
- childrenResolved
- resolve
- resolveChildren
- resolveExpressions
- resolveOperators
- resolveQuoted
- sameResult
- statistics
-
sql/catalyst/trees/TreeNode.js
- apply
- argString
- asCode
- children
- collect
- collectFirst
- fastEquals
- find
- flatMap
- foreach
- foreachUp
- makeCopy
- map
- mapChildren
- nodeName
- numberedTreeString
- simpleString
- toString
- transform
- transformDown
- transformUp
- treeString
- withNewChildren
-
streaming/DStream.js
- cache X
- compute X
- filter X
- persist X
- repartition X
- union X
- window X
- wrapRDD
-
streaming/Duration.js
- div X
- greater X
- greaterEq X
- isMultipleOf X
- isZero X
- less X
- lessEq X
- max X
- milliseconds X
- min X
- minus X
- plus X
- prettyPrint
- times X
- toFormattedString
- toString
-
streaming/InputDStream.js
-
streaming/MapWithStateDStream.js
- stateSnapshots
-
streaming/PairDStream.js
- cache X
- cogroup
- combineByKey X
- compute X
- filter X
- flatMapValues X
- fullOuterJoin
- groupByKey X
- groupByKeyAndWindow
- join
- leftOuterJoin
- mapValues X
- mapWithState
- persist X
- reduceByKey X
- reduceByKeyAndWindow X
- repartition X
- rightOuterJoin
- saveAsHadoopFiles
- saveAsNewAPIHadoopFiles
- toJavaDStream
- union X
- updateStateByKey
- window X
- wrapRDD
-
streaming/PairInputDStream.js
-
streaming/ReceiverInputDStream.js
-
streaming/StateSpec.js
- initialStatewithJavaPairRDD
- initialStatewithRDD
- numPartitions
- partitioner
- timeout
-
streaming/StreamingContext.js
- actorStream
- addStreamingListener
- awaitTermination X
- awaitTerminationOrTimeout X
- binaryRecordsStream
- checkpoint X
- close X
- fileStream
- queueStream X
- rawSocketStream
- receiverStream
- remember
- socketStream
- socketTextStream X
- start X
- stop X
- textFileStream
- transform
- transformToPair
- unionwithJList
-
streaming/Time.js
- floor X
- greater X
- greaterEq X
- isMultipleOf X
- less X
- lessEq X
- max X
- milliseconds X
- min X
- minuswithDuration
- minuswithTime
- plus X
- to X
- toString X
- until X
-
streaming/dstream/DStream.js
- cache X
- checkpoint X
- compute X
- context X
- count X
- countByValue X
- countByValueAndWindow X
- countByWindow X
- dependencies
- filter X
- flatMap X
- foreachRDDwithfunc
- glom X
- map X
- mapPartitions X
- persist X
- print X
- reduce X
- reduceByWindow X
- reduceByWindowwithSlideDuration X
- repartition X
- saveAsTextFiles
- slice
- slicewithToTime
- slideDuration
- transformWithwithfunc
- transformwithfunc
- union X
- window X