SlideShare a Scribd company logo
1 of 114
1Pivotal Confidential–Internal Use Only 1Pivotal Confidential–Internal Use Only
Spark Architecture
A.Grishchenko
About me
Enterprise Architect @ Pivotal
 7 years in data processing
 5 years with MPP
 4 years with Hadoop
 Spark contributor
 http://0x0fff.com
Outline
 Spark Motivation
 Spark Pillars
 Spark Architecture
 Spark Shuffle
 Spark DataFrame
Outline
 Spark Motivation
 Spark Pillars
 Spark Architecture
 Spark Shuffle
 Spark DataFrame
Spark Motivation
 Difficultly of programming directly in Hadoop MapReduce
Spark Motivation
 Difficultly of programming directly in Hadoop MapReduce
 Performance bottlenecks, or batch not fitting use cases
Spark Motivation
 Difficultly of programming directly in Hadoop MapReduce
 Performance bottlenecks, or batch not fitting use cases
 Better support iterative jobs typical for machine learning
Difficulty of Programming in MR
Word Count implementations
 Hadoop MR – 61 lines in Java
 Spark – 1 line in interactive shell
sc.textFile('...').flatMap(lambda x: x.split())
.map(lambda x: (x, 1)).reduceByKey(lambda x, y: x+y)
.saveAsTextFile('...')
VS
Performance Bottlenecks
How many times the data is put to the HDD during a single
MapReduce Job?
 One
 Two
 Three
 More
Performance Bottlenecks
How many times the data is put to the HDD during a single
MapReduce Job?
 One
 Two
 Three
 More
Performance Bottlenecks
Consider Hive as main SQL tool
Performance Bottlenecks
Consider Hive as main SQL tool
 Typical Hive query is translated to 3-5 MR jobs
Performance Bottlenecks
Consider Hive as main SQL tool
 Typical Hive query is translated to 3-5 MR jobs
 Each MR would scan put data to HDD 3+ times
Performance Bottlenecks
Consider Hive as main SQL tool
 Typical Hive query is translated to 3-5 MR jobs
 Each MR would scan put data to HDD 3+ times
 Each put to HDD – write followed by read
Performance Bottlenecks
Consider Hive as main SQL tool
 Typical Hive query is translated to 3-5 MR jobs
 Each MR would scan put data to HDD 3+ times
 Each put to HDD – write followed by read
 Sums up to 18-30 scans of data during a single
Hive query
Performance Bottlenecks
Spark offers you
 Lazy Computations
– Optimize the job before executing
Performance Bottlenecks
Spark offers you
 Lazy Computations
– Optimize the job before executing
 In-memory data caching
– Scan HDD only once, then scan your RAM
Performance Bottlenecks
Spark offers you
 Lazy Computations
– Optimize the job before executing
 In-memory data caching
– Scan HDD only once, then scan your RAM
 Efficient pipelining
– Avoids the data hitting the HDD by all means
Outline
 Spark Motivation
 Spark Pillars
 Spark Architecture
 Spark Shuffle
 Spark DataFrame
Spark Pillars
Two main abstractions of Spark
Spark Pillars
Two main abstractions of Spark
 RDD – Resilient Distributed Dataset
Spark Pillars
Two main abstractions of Spark
 RDD – Resilient Distributed Dataset
 DAG – Direct Acyclic Graph
RDD
 Simple view
– RDD is collection of data items split into partitions and
stored in memory on worker nodes of the cluster
RDD
 Simple view
– RDD is collection of data items split into partitions and
stored in memory on worker nodes of the cluster
 Complex view
– RDD is an interface for data transformation
RDD
 Simple view
– RDD is collection of data items split into partitions and
stored in memory on worker nodes of the cluster
 Complex view
– RDD is an interface for data transformation
– RDD refers to the data stored either in persisted store
(HDFS, Cassandra, HBase, etc.) or in cache (memory,
memory+disks, disk only, etc.) or in another RDD
RDD
 Complex view (cont’d)
– Partitions are recomputed on failure or cache eviction
RDD
 Complex view (cont’d)
– Partitions are recomputed on failure or cache eviction
– Metadata stored for interface
▪ Partitions – set of data splits associated with this RDD
RDD
 Complex view (cont’d)
– Partitions are recomputed on failure or cache eviction
– Metadata stored for interface
▪ Partitions – set of data splits associated with this RDD
▪ Dependencies – list of parent RDDs involved in computation
RDD
 Complex view (cont’d)
– Partitions are recomputed on failure or cache eviction
– Metadata stored for interface
▪ Partitions – set of data splits associated with this RDD
▪ Dependencies – list of parent RDDs involved in computation
▪ Compute – function to compute partition of the RDD given the
parent partitions from the Dependencies
RDD
 Complex view (cont’d)
– Partitions are recomputed on failure or cache eviction
– Metadata stored for interface
▪ Partitions – set of data splits associated with this RDD
▪ Dependencies – list of parent RDDs involved in computation
▪ Compute – function to compute partition of the RDD given the
parent partitions from the Dependencies
▪ Preferred Locations – where is the best place to put
computations on this partition (data locality)
RDD
 Complex view (cont’d)
– Partitions are recomputed on failure or cache eviction
– Metadata stored for interface
▪ Partitions – set of data splits associated with this RDD
▪ Dependencies – list of parent RDDs involved in computation
▪ Compute – function to compute partition of the RDD given the
parent partitions from the Dependencies
▪ Preferred Locations – where is the best place to put
computations on this partition (data locality)
▪ Partitioner – how the data is split into partitions
RDD
 RDD is the main and only tool for data
manipulation in Spark
 Two classes of operations
– Transformations
– Actions
RDD
Lazy computations model
Transformation cause only metadata change
DAG
Direct Acyclic Graph – sequence of computations
performed on data
DAG
Direct Acyclic Graph – sequence of computations
performed on data
 Node – RDD partition
DAG
Direct Acyclic Graph – sequence of computations
performed on data
 Node – RDD partition
 Edge – transformation on top of data
DAG
Direct Acyclic Graph – sequence of computations
performed on data
 Node – RDD partition
 Edge – transformation on top of data
 Acyclic – graph cannot return to the older partition
DAG
Direct Acyclic Graph – sequence of computations
performed on data
 Node – RDD partition
 Edge – transformation on top of data
 Acyclic – graph cannot return to the older partition
 Direct – transformation is an action that transitions
data partition state (from A to B)
DAG
WordCount example
DAG
WordCount example
HDFSInputSplits
HDFS
RDDPartitions
RDD RDD RDD RDD RDD
sc.textFile(‘hdfs://…’) flatMap map reduceByKey foreach
Outline
 Spark Motivation
 Spark Pillars
 Spark Architecture
 Spark Shuffle
 Spark DataFrames
Spark Cluster
Driver Node
…
Worker Node Worker Node Worker Node
Spark Cluster
Driver Node
Driver
…
Worker Node
…
Executor Executor
Worker Node
…
Executor Executor
Worker Node
…
Executor Executor
Spark Cluster
Driver Node
Driver
Spark Context
…
Worker Node
…
Executor
Cache
Executor
Cache
Worker Node
…
Executor
Cache
Executor
Cache
Worker Node
…
Executor
Cache
Executor
Cache
Spark Cluster
Driver Node
Driver
Spark Context
…
Worker Node
…
Executor
Cache
Task
…
Task
Task
Executor
Cache
Task
…
Task
Task
Worker Node
…
Executor
Cache
Task
…
Task
Task
Executor
Cache
Task
…
Task
Task
Worker Node
…
Executor
Cache
Task
…
Task
Task
Executor
Cache
Task
…
Task
Task
Spark Cluster
 Driver
– Entry point of the Spark Shell (Scala, Python, R)
Spark Cluster
 Driver
– Entry point of the Spark Shell (Scala, Python, R)
– The place where SparkContext is created
Spark Cluster
 Driver
– Entry point of the Spark Shell (Scala, Python, R)
– The place where SparkContext is created
– Translates RDD into the execution graph
Spark Cluster
 Driver
– Entry point of the Spark Shell (Scala, Python, R)
– The place where SparkContext is created
– Translates RDD into the execution graph
– Splits graph into stages
Spark Cluster
 Driver
– Entry point of the Spark Shell (Scala, Python, R)
– The place where SparkContext is created
– Translates RDD into the execution graph
– Splits graph into stages
– Schedules tasks and controls their execution
Spark Cluster
 Driver
– Entry point of the Spark Shell (Scala, Python, R)
– The place where SparkContext is created
– Translates RDD into the execution graph
– Splits graph into stages
– Schedules tasks and controls their execution
– Stores metadata about all the RDDs and their partitions
Spark Cluster
 Driver
– Entry point of the Spark Shell (Scala, Python, R)
– The place where SparkContext is created
– Translates RDD into the execution graph
– Splits graph into stages
– Schedules tasks and controls their execution
– Stores metadata about all the RDDs and their partitions
– Brings up Spark WebUI with job information
Spark Cluster
 Executor
– Stores the data in cache in JVM heap or on HDDs
Spark Cluster
 Executor
– Stores the data in cache in JVM heap or on HDDs
– Reads data from external sources
Spark Cluster
 Executor
– Stores the data in cache in JVM heap or on HDDs
– Reads data from external sources
– Writes data to external sources
Spark Cluster
 Executor
– Stores the data in cache in JVM heap or on HDDs
– Reads data from external sources
– Writes data to external sources
– Performs all the data processing
Executor Memory
Spark Cluster – Detailed
Spark Cluster – PySpark
Application Decomposition
 Application
– Single instance of SparkContext that stores some data
processing logic and can schedule series of jobs,
sequentially or in parallel (SparkContext is thread-safe)
Application Decomposition
 Application
– Single instance of SparkContext that stores some data
processing logic and can schedule series of jobs,
sequentially or in parallel (SparkContext is thread-safe)
 Job
– Complete set of transformations on RDD that finishes
with action or data saving, triggered by the driver
application
Application Decomposition
 Stage
– Set of transformations that can be pipelined and
executed by a single independent worker. Usually it is
app the transformations between “read”, “shuffle”,
“action”, “save”
Application Decomposition
 Stage
– Set of transformations that can be pipelined and
executed by a single independent worker. Usually it is
app the transformations between “read”, “shuffle”,
“action”, “save”
 Task
– Execution of the stage on a single data partition. Basic
unit of scheduling
WordCount ExampleHDFSInputSplits
HDFS
RDDPartitions
RDD RDD RDD RDD RDD
sc.textFile(‘hdfs://…’) flatMap map reduceByKey foreach
Stage 1
WordCount ExampleHDFSInputSplits
HDFS
RDDPartitions
RDD RDD RDD RDD RDD
sc.textFile(‘hdfs://…’) flatMap map reduceByKey foreach
Stage 2Stage 1
WordCount ExampleHDFSInputSplits
HDFS
RDDPartitions
RDD RDD RDD RDD RDD
sc.textFile(‘hdfs://…’) flatMap map reduceByKey foreach
Stage 2Stage 1
WordCount ExampleHDFSInputSplits
HDFS
RDDPartitions
RDD RDD RDD RDD RDD
sc.textFile(‘hdfs://…’) flatMap map reduceByKey foreach
Task 1
Task 2
Task 3
Task 4
Stage 2Stage 1
WordCount ExampleHDFSInputSplits
HDFS
RDDPartitions
RDD RDD RDD RDD RDD
sc.textFile(‘hdfs://…’) flatMap map reduceByKey foreach
Task 1
Task 2
Task 3
Task 4
Task 5
Task 6
Task 7
Task 8
Stage 2Stage 1
WordCount ExampleHDFSInputSplits
HDFS
pipeline
Task 1
Task 2
Task 3
Task 4
Task 5
Task 6
Task 7
Task 8
partition shuffle pipeline
Persistence in Spark
Persistence Level Description
MEMORY_ONLY Store RDD as deserialized Java objects in the JVM. If the RDD does not fit in
memory, some partitions will not be cached and will be recomputed on the fly each
time they're needed. This is the default level.
MEMORY_AND_DISK Store RDD as deserialized Java objects in the JVM. If the RDD does not fit in
memory, store the partitions that don't fit on disk, and read them from there when
they're needed.
MEMORY_ONLY_SER Store RDD as serialized Java objects (one byte array per partition). This is
generally more space-efficient than deserialized objects, especially when using a
fast serializer, but more CPU-intensive to read.
MEMORY_AND_DISK_SER Similar to MEMORY_ONLY_SER, but spill partitions that don't fit in memory to disk
instead of recomputing them on the fly each time they're needed.
DISK_ONLY Store the RDD partitions only on disk.
MEMORY_ONLY_2,
DISK_ONLY_2, etc.
Same as the levels above, but replicate each partition on two cluster nodes.
Persistence in Spark
 Spark considers memory as a cache with LRU
eviction rules
 If “Disk” is involved, data is evicted to disks
rdd = sc.parallelize(xrange(1000))
rdd.cache().count()
rdd.persist(StorageLevel.MEMORY_AND_DISK_SER).count()
rdd.unpersist()
Outline
 Spark Motivation
 Spark Pillars
 Spark Architecture
 Spark Shuffle
 Spark DataFrame
Shuffles in Spark
 Hash Shuffle – default prior to 1.2.0
Shuffles in Spark
 Hash Shuffle – default prior to 1.2.0
 Sort Shuffle – default now
Shuffles in Spark
 Hash Shuffle – default prior to 1.2.0
 Sort Shuffle – default now
 Tungsten Sort – new optimized one!
Hash Shuffle
Executor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Hash Shuffle
Executor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
“map” task
spark.executor.cores/
spark.task.cpus
…
Hash Shuffle
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
“map” task
spark.executor.cores/
spark.task.cpus
…
Output File
Output File
Output File
…
Numberof
“Reducers”
spark.local.dir
Hash Shuffle
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
“map” task
spark.executor.cores/
spark.task.cpus
…
Output File
Output File
Output File
…
Numberof
“Reducers”
Output File
Output File
Output File
…
Numberof
“Reducers”
…
spark.local.dir
Hash Shuffle
Numberof“map”tasks
executedbythisexecutor
Hash Shuffle with Consolidation
Executor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Hash Shuffle With Consolidation
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
…
Numberof
“Reducers”
Output File
Output File
Output File
spark.local.dir
Hash Shuffle With Consolidationspark.executor.cores/
spark.task.cpus
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
“map” task
…
…
…
Numberof
“Reducers”
spark.local.dir
Hash Shuffle With Consolidationspark.executor.cores/
spark.task.cpus
spark.executor.cores/
spark.task.cpus
…
Numberof
“Reducers”
Output File
Output File
Output File
Output File
Output File
Output File
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
…
…
…
Numberof
“Reducers”
spark.local.dir
Hash Shuffle With Consolidationspark.executor.cores/
spark.task.cpus
spark.executor.cores/
spark.task.cpus
…
Numberof
“Reducers”
Output File
Output File
Output File
Output File
Output File
Output File
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
“map” task
…
…
…
Numberof
“Reducers”
spark.local.dir
Hash Shuffle With Consolidationspark.executor.cores/
spark.task.cpus
spark.executor.cores/
spark.task.cpus
Output File
Output File
Output File
…
Numberof
“Reducers”
Output File
Output File
Output File
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
…
…
…
Numberof
“Reducers”
spark.local.dir
Hash Shuffle With Consolidationspark.executor.cores/
spark.task.cpus
spark.executor.cores/
spark.task.cpus
Output File
Output File
Output File
…
Numberof
“Reducers”
Output File
Output File
Output File
Local DirectoryExecutor JVM
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map” task
“map” task
…
…
…
Numberof
“Reducers”
spark.local.dir
Hash Shuffle With Consolidationspark.executor.cores/
spark.task.cpus
spark.executor.cores/
spark.task.cpus
…
Numberof
“Reducers”
Output File
Output File
Output File
Output File
Output File
Output File
Sort Shuffle
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
Partition
Partition
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
Partition
Partition
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
AppendOnlyMap
…
AppendOnlyMap
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
AppendOnlyMap
…
AppendOnlyMap
sort &
spill
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
AppendOnlyMap
…
AppendOnlyMap
sort &
spill
Local
Directory
Output File
index
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
AppendOnlyMap
…
AppendOnlyMap
sort &
spill
sort &
spill
Local
Directory
Output File
index
Output File
index
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
AppendOnlyMap
…
AppendOnlyMap
sort &
spill
sort &
spill
sort &
spill
…
Local
Directory
…
Output File
index
Output File
index
Output File
index
spark.executor.cores/spark.task.cpus
MinHeap
Merge
MinHeap
Merge
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
AppendOnlyMap
…
AppendOnlyMap
sort &
spill
sort &
spill
sort &
spill
…
Local
Directory
…
“reduce”task“reduce”task
…Output File
index
Output File
index
Output File
index
spark.executor.cores/spark.task.cpus
Tungsten Sort Shuffle
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
Partition
Partition
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
Partition
Partition
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
Array of data pointers and
Partition IDs, long[]
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
Array of data pointers and
Partition IDs, long[]
sort &
spill
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
Local Directory
Array of data pointers and
Partition IDs, long[]
sort &
spill
spark.local.dir
Output File
partition
partition
partition
partition
index
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
Local Directory
Array of data pointers and
Partition IDs, long[]
sort &
spill
sort &
spill
…
spark.local.dir
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
Local Directory
Array of data pointers and
Partition IDs, long[]
sort &
spill
sort &
spill
…
spark.local.dir
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
…
Local Directory
Array of data pointers and
Partition IDs, long[]
Serialized Data
LinkedList<MemoryBlock>
Array of data pointers and
Partition IDs, long[]
sort &
spill
sort &
spill
…
spark.local.dir
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
…
Local Directory
…
Array of data pointers and
Partition IDs, long[]
Serialized Data
LinkedList<MemoryBlock>
Array of data pointers and
Partition IDs, long[]
sort &
spill
sort &
spill
…
sort &
spill
spark.local.dir
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
spark.executor.cores/spark.task.cpus
Executor JVMPartition
Partition
Partition
Partition
Partition
Partition
Partition
Partition
“map”
task
“map”
task
…
Tungsten Sort Shuffle
spark.storage.[safetyFraction * memoryFraction]
spark.shuffle.
[safetyFraction * memoryFraction]
Partition
Partition
Serialized Data
LinkedList<MemoryBlock>
…
Local Directory
…
Array of data pointers and
Partition IDs, long[]
Serialized Data
LinkedList<MemoryBlock>
Array of data pointers and
Partition IDs, long[]
sort &
spill
sort &
spill
…
sort &
spill
spark.local.dir
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
Output File
partition
partition
partition
partition
index
merge
spark.executor.cores/spark.task.cpus
Outline
 Spark Motivation
 Spark Pillars
 Spark Architecture
 Spark Shuffle
 Spark DataFrame
DataFrame Idea
DataFrame Implementation
 Interface
– DataFrame is an RDD with schema – field names, field
data types and statistics
– Unified transformation interface in all languages, all the
transformations are passed to JVM
– Can be accessed as RDD, in this case transformed to
the RDD of Row objects
DataFrame Implementation
 Internals
– Internally it is the same RDD
– Data is stored in row-columnar format, row chunk size
is set by spark.sql.inMemoryColumnarStorage.batchSize
– Each column in each partition stores min-max values
for partition pruning
– Allows better compression ratio than standard RDD
– Delivers faster performance for small subsets of
columns
113Pivotal Confidential–Internal Use Only 113Pivotal Confidential–Internal Use Only
Questions?
BUILT FOR THE SPEED OF BUSINESS

More Related Content

What's hot

Introduction to Redis
Introduction to RedisIntroduction to Redis
Introduction to Redis
Dvir Volk
 
HBase and HDFS: Understanding FileSystem Usage in HBase
HBase and HDFS: Understanding FileSystem Usage in HBaseHBase and HDFS: Understanding FileSystem Usage in HBase
HBase and HDFS: Understanding FileSystem Usage in HBase
enissoz
 
Hive + Tez: A Performance Deep Dive
Hive + Tez: A Performance Deep DiveHive + Tez: A Performance Deep Dive
Hive + Tez: A Performance Deep Dive
DataWorks Summit
 
Apache Tez - A New Chapter in Hadoop Data Processing
Apache Tez - A New Chapter in Hadoop Data ProcessingApache Tez - A New Chapter in Hadoop Data Processing
Apache Tez - A New Chapter in Hadoop Data Processing
DataWorks Summit
 

What's hot (20)

Introduction to Redis
Introduction to RedisIntroduction to Redis
Introduction to Redis
 
Apache Spark in Depth: Core Concepts, Architecture & Internals
Apache Spark in Depth: Core Concepts, Architecture & InternalsApache Spark in Depth: Core Concepts, Architecture & Internals
Apache Spark in Depth: Core Concepts, Architecture & Internals
 
From cache to in-memory data grid. Introduction to Hazelcast.
From cache to in-memory data grid. Introduction to Hazelcast.From cache to in-memory data grid. Introduction to Hazelcast.
From cache to in-memory data grid. Introduction to Hazelcast.
 
HBase and HDFS: Understanding FileSystem Usage in HBase
HBase and HDFS: Understanding FileSystem Usage in HBaseHBase and HDFS: Understanding FileSystem Usage in HBase
HBase and HDFS: Understanding FileSystem Usage in HBase
 
Apache Spark Introduction and Resilient Distributed Dataset basics and deep dive
Apache Spark Introduction and Resilient Distributed Dataset basics and deep diveApache Spark Introduction and Resilient Distributed Dataset basics and deep dive
Apache Spark Introduction and Resilient Distributed Dataset basics and deep dive
 
Building Robust ETL Pipelines with Apache Spark
Building Robust ETL Pipelines with Apache SparkBuilding Robust ETL Pipelines with Apache Spark
Building Robust ETL Pipelines with Apache Spark
 
A Tale of Three Apache Spark APIs: RDDs, DataFrames, and Datasets with Jules ...
A Tale of Three Apache Spark APIs: RDDs, DataFrames, and Datasets with Jules ...A Tale of Three Apache Spark APIs: RDDs, DataFrames, and Datasets with Jules ...
A Tale of Three Apache Spark APIs: RDDs, DataFrames, and Datasets with Jules ...
 
Running Apache Spark on Kubernetes: Best Practices and Pitfalls
Running Apache Spark on Kubernetes: Best Practices and PitfallsRunning Apache Spark on Kubernetes: Best Practices and Pitfalls
Running Apache Spark on Kubernetes: Best Practices and Pitfalls
 
Spark introduction and architecture
Spark introduction and architectureSpark introduction and architecture
Spark introduction and architecture
 
Hive + Tez: A Performance Deep Dive
Hive + Tez: A Performance Deep DiveHive + Tez: A Performance Deep Dive
Hive + Tez: A Performance Deep Dive
 
Introduction to Apache Spark
Introduction to Apache SparkIntroduction to Apache Spark
Introduction to Apache Spark
 
Apache Spark Fundamentals
Apache Spark FundamentalsApache Spark Fundamentals
Apache Spark Fundamentals
 
A Deep Dive into Spark SQL's Catalyst Optimizer with Yin Huai
A Deep Dive into Spark SQL's Catalyst Optimizer with Yin HuaiA Deep Dive into Spark SQL's Catalyst Optimizer with Yin Huai
A Deep Dive into Spark SQL's Catalyst Optimizer with Yin Huai
 
Spark SQL Deep Dive @ Melbourne Spark Meetup
Spark SQL Deep Dive @ Melbourne Spark MeetupSpark SQL Deep Dive @ Melbourne Spark Meetup
Spark SQL Deep Dive @ Melbourne Spark Meetup
 
Spark shuffle introduction
Spark shuffle introductionSpark shuffle introduction
Spark shuffle introduction
 
Parquet performance tuning: the missing guide
Parquet performance tuning: the missing guideParquet performance tuning: the missing guide
Parquet performance tuning: the missing guide
 
Apache Tez - A New Chapter in Hadoop Data Processing
Apache Tez - A New Chapter in Hadoop Data ProcessingApache Tez - A New Chapter in Hadoop Data Processing
Apache Tez - A New Chapter in Hadoop Data Processing
 
Introduction to Apache Flink - Fast and reliable big data processing
Introduction to Apache Flink - Fast and reliable big data processingIntroduction to Apache Flink - Fast and reliable big data processing
Introduction to Apache Flink - Fast and reliable big data processing
 
Top 5 Mistakes When Writing Spark Applications
Top 5 Mistakes When Writing Spark ApplicationsTop 5 Mistakes When Writing Spark Applications
Top 5 Mistakes When Writing Spark Applications
 
Apache Spark Core—Deep Dive—Proper Optimization
Apache Spark Core—Deep Dive—Proper OptimizationApache Spark Core—Deep Dive—Proper Optimization
Apache Spark Core—Deep Dive—Proper Optimization
 

Viewers also liked

Simplifying Big Data Analytics with Apache Spark
Simplifying Big Data Analytics with Apache SparkSimplifying Big Data Analytics with Apache Spark
Simplifying Big Data Analytics with Apache Spark
Databricks
 
Hands on MapR -- Viadea
Hands on MapR -- ViadeaHands on MapR -- Viadea
Hands on MapR -- Viadea
viadea
 

Viewers also liked (20)

Modern Data Architecture
Modern Data ArchitectureModern Data Architecture
Modern Data Architecture
 
Introduction to Spark Internals
Introduction to Spark InternalsIntroduction to Spark Internals
Introduction to Spark Internals
 
Apache Spark 2.0: Faster, Easier, and Smarter
Apache Spark 2.0: Faster, Easier, and SmarterApache Spark 2.0: Faster, Easier, and Smarter
Apache Spark 2.0: Faster, Easier, and Smarter
 
Apache HAWQ Architecture
Apache HAWQ ArchitectureApache HAWQ Architecture
Apache HAWQ Architecture
 
MPP vs Hadoop
MPP vs HadoopMPP vs Hadoop
MPP vs Hadoop
 
Introduction to Apache Spark Developer Training
Introduction to Apache Spark Developer TrainingIntroduction to Apache Spark Developer Training
Introduction to Apache Spark Developer Training
 
Deep Dive: Memory Management in Apache Spark
Deep Dive: Memory Management in Apache SparkDeep Dive: Memory Management in Apache Spark
Deep Dive: Memory Management in Apache Spark
 
Data Storage Tips for Optimal Spark Performance-(Vida Ha, Databricks)
Data Storage Tips for Optimal Spark Performance-(Vida Ha, Databricks)Data Storage Tips for Optimal Spark Performance-(Vida Ha, Databricks)
Data Storage Tips for Optimal Spark Performance-(Vida Ha, Databricks)
 
SQL to Hive Cheat Sheet
SQL to Hive Cheat SheetSQL to Hive Cheat Sheet
SQL to Hive Cheat Sheet
 
How to understand and analyze Apache Hive query execution plan for performanc...
How to understand and analyze Apache Hive query execution plan for performanc...How to understand and analyze Apache Hive query execution plan for performanc...
How to understand and analyze Apache Hive query execution plan for performanc...
 
MapR Tutorial Series
MapR Tutorial SeriesMapR Tutorial Series
MapR Tutorial Series
 
Apache Spark & Hadoop
Apache Spark & HadoopApache Spark & Hadoop
Apache Spark & Hadoop
 
AWS re:Invent 2016: Fraud Detection with Amazon Machine Learning on AWS (FIN301)
AWS re:Invent 2016: Fraud Detection with Amazon Machine Learning on AWS (FIN301)AWS re:Invent 2016: Fraud Detection with Amazon Machine Learning on AWS (FIN301)
AWS re:Invent 2016: Fraud Detection with Amazon Machine Learning on AWS (FIN301)
 
MapR and Cisco Make IT Better
MapR and Cisco Make IT BetterMapR and Cisco Make IT Better
MapR and Cisco Make IT Better
 
Simplifying Big Data Analytics with Apache Spark
Simplifying Big Data Analytics with Apache SparkSimplifying Big Data Analytics with Apache Spark
Simplifying Big Data Analytics with Apache Spark
 
Deep Learning for Fraud Detection
Deep Learning for Fraud DetectionDeep Learning for Fraud Detection
Deep Learning for Fraud Detection
 
MapR M7: Providing an enterprise quality Apache HBase API
MapR M7: Providing an enterprise quality Apache HBase APIMapR M7: Providing an enterprise quality Apache HBase API
MapR M7: Providing an enterprise quality Apache HBase API
 
Hands on MapR -- Viadea
Hands on MapR -- ViadeaHands on MapR -- Viadea
Hands on MapR -- Viadea
 
Architectural Overview of MapR's Apache Hadoop Distribution
Architectural Overview of MapR's Apache Hadoop DistributionArchitectural Overview of MapR's Apache Hadoop Distribution
Architectural Overview of MapR's Apache Hadoop Distribution
 
Hadoop MapReduce Fundamentals
Hadoop MapReduce FundamentalsHadoop MapReduce Fundamentals
Hadoop MapReduce Fundamentals
 

Similar to Apache Spark Architecture

Big Data Processing using Apache Spark and Clojure
Big Data Processing using Apache Spark and ClojureBig Data Processing using Apache Spark and Clojure
Big Data Processing using Apache Spark and Clojure
Dr. Christian Betz
 

Similar to Apache Spark Architecture (20)

Spark
SparkSpark
Spark
 
Bigdata processing with Spark - part II
Bigdata processing with Spark - part IIBigdata processing with Spark - part II
Bigdata processing with Spark - part II
 
Spark learning
Spark learningSpark learning
Spark learning
 
Geek Night - Functional Data Processing using Spark and Scala
Geek Night - Functional Data Processing using Spark and ScalaGeek Night - Functional Data Processing using Spark and Scala
Geek Night - Functional Data Processing using Spark and Scala
 
Apache Spark and DataStax Enablement
Apache Spark and DataStax EnablementApache Spark and DataStax Enablement
Apache Spark and DataStax Enablement
 
Apache Spark Introduction.pdf
Apache Spark Introduction.pdfApache Spark Introduction.pdf
Apache Spark Introduction.pdf
 
A Deep Dive Into Spark
A Deep Dive Into SparkA Deep Dive Into Spark
A Deep Dive Into Spark
 
Big Data Processing using Apache Spark and Clojure
Big Data Processing using Apache Spark and ClojureBig Data Processing using Apache Spark and Clojure
Big Data Processing using Apache Spark and Clojure
 
Apache Spark Fundamentals Meetup Talk
Apache Spark Fundamentals Meetup TalkApache Spark Fundamentals Meetup Talk
Apache Spark Fundamentals Meetup Talk
 
Paris Data Geek - Spark Streaming
Paris Data Geek - Spark Streaming Paris Data Geek - Spark Streaming
Paris Data Geek - Spark Streaming
 
Spark Summit East 2015 Advanced Devops Student Slides
Spark Summit East 2015 Advanced Devops Student SlidesSpark Summit East 2015 Advanced Devops Student Slides
Spark Summit East 2015 Advanced Devops Student Slides
 
Big data processing with Apache Spark and Oracle Database
Big data processing with Apache Spark and Oracle DatabaseBig data processing with Apache Spark and Oracle Database
Big data processing with Apache Spark and Oracle Database
 
Intro to Apache Spark
Intro to Apache SparkIntro to Apache Spark
Intro to Apache Spark
 
Intro to Apache Spark
Intro to Apache SparkIntro to Apache Spark
Intro to Apache Spark
 
HKOSCon18 - Chetan Khatri - Scaling TB's of Data with Apache Spark and Scala ...
HKOSCon18 - Chetan Khatri - Scaling TB's of Data with Apache Spark and Scala ...HKOSCon18 - Chetan Khatri - Scaling TB's of Data with Apache Spark and Scala ...
HKOSCon18 - Chetan Khatri - Scaling TB's of Data with Apache Spark and Scala ...
 
Spark SQL
Spark SQLSpark SQL
Spark SQL
 
Intro to Spark
Intro to SparkIntro to Spark
Intro to Spark
 
A really really fast introduction to PySpark - lightning fast cluster computi...
A really really fast introduction to PySpark - lightning fast cluster computi...A really really fast introduction to PySpark - lightning fast cluster computi...
A really really fast introduction to PySpark - lightning fast cluster computi...
 
Introduction to Apache Spark
Introduction to Apache SparkIntroduction to Apache Spark
Introduction to Apache Spark
 
Introduction to Apache Spark
Introduction to Apache Spark Introduction to Apache Spark
Introduction to Apache Spark
 

Recently uploaded

怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制
怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制
怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制
vexqp
 
Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...
Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...
Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...
ZurliaSoop
 
Jual Cytotec Asli Obat Aborsi No. 1 Paling Manjur
Jual Cytotec Asli Obat Aborsi No. 1 Paling ManjurJual Cytotec Asli Obat Aborsi No. 1 Paling Manjur
Jual Cytotec Asli Obat Aborsi No. 1 Paling Manjur
ptikerjasaptiker
 
Reconciling Conflicting Data Curation Actions: Transparency Through Argument...
Reconciling Conflicting Data Curation Actions:  Transparency Through Argument...Reconciling Conflicting Data Curation Actions:  Transparency Through Argument...
Reconciling Conflicting Data Curation Actions: Transparency Through Argument...
Bertram Ludäscher
 
Gartner's Data Analytics Maturity Model.pptx
Gartner's Data Analytics Maturity Model.pptxGartner's Data Analytics Maturity Model.pptx
Gartner's Data Analytics Maturity Model.pptx
chadhar227
 
Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...
nirzagarg
 
Cytotec in Jeddah+966572737505) get unwanted pregnancy kit Riyadh
Cytotec in Jeddah+966572737505) get unwanted pregnancy kit RiyadhCytotec in Jeddah+966572737505) get unwanted pregnancy kit Riyadh
Cytotec in Jeddah+966572737505) get unwanted pregnancy kit Riyadh
Abortion pills in Riyadh +966572737505 get cytotec
 
怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制
怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制
怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制
vexqp
 
怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制
怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制
怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制
vexqp
 
+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...
+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...
+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...
Health
 
Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...
nirzagarg
 
Abortion pills in Doha Qatar (+966572737505 ! Get Cytotec
Abortion pills in Doha Qatar (+966572737505 ! Get CytotecAbortion pills in Doha Qatar (+966572737505 ! Get Cytotec
Abortion pills in Doha Qatar (+966572737505 ! Get Cytotec
Abortion pills in Riyadh +966572737505 get cytotec
 
Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...
Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...
Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...
nirzagarg
 
Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...
Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...
Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...
nirzagarg
 

Recently uploaded (20)

怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制
怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制
怎样办理伦敦大学毕业证(UoL毕业证书)成绩单学校原版复制
 
7. Epi of Chronic respiratory diseases.ppt
7. Epi of Chronic respiratory diseases.ppt7. Epi of Chronic respiratory diseases.ppt
7. Epi of Chronic respiratory diseases.ppt
 
Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...
Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...
Jual Obat Aborsi Surabaya ( Asli No.1 ) 085657271886 Obat Penggugur Kandungan...
 
Jual Cytotec Asli Obat Aborsi No. 1 Paling Manjur
Jual Cytotec Asli Obat Aborsi No. 1 Paling ManjurJual Cytotec Asli Obat Aborsi No. 1 Paling Manjur
Jual Cytotec Asli Obat Aborsi No. 1 Paling Manjur
 
Digital Transformation Playbook by Graham Ware
Digital Transformation Playbook by Graham WareDigital Transformation Playbook by Graham Ware
Digital Transformation Playbook by Graham Ware
 
Reconciling Conflicting Data Curation Actions: Transparency Through Argument...
Reconciling Conflicting Data Curation Actions:  Transparency Through Argument...Reconciling Conflicting Data Curation Actions:  Transparency Through Argument...
Reconciling Conflicting Data Curation Actions: Transparency Through Argument...
 
Capstone in Interprofessional Informatic // IMPACT OF COVID 19 ON EDUCATION
Capstone in Interprofessional Informatic  // IMPACT OF COVID 19 ON EDUCATIONCapstone in Interprofessional Informatic  // IMPACT OF COVID 19 ON EDUCATION
Capstone in Interprofessional Informatic // IMPACT OF COVID 19 ON EDUCATION
 
Gartner's Data Analytics Maturity Model.pptx
Gartner's Data Analytics Maturity Model.pptxGartner's Data Analytics Maturity Model.pptx
Gartner's Data Analytics Maturity Model.pptx
 
DATA SUMMIT 24 Building Real-Time Pipelines With FLaNK
DATA SUMMIT 24  Building Real-Time Pipelines With FLaNKDATA SUMMIT 24  Building Real-Time Pipelines With FLaNK
DATA SUMMIT 24 Building Real-Time Pipelines With FLaNK
 
Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Satna [ 7014168258 ] Call Me For Genuine Models We ...
 
Cytotec in Jeddah+966572737505) get unwanted pregnancy kit Riyadh
Cytotec in Jeddah+966572737505) get unwanted pregnancy kit RiyadhCytotec in Jeddah+966572737505) get unwanted pregnancy kit Riyadh
Cytotec in Jeddah+966572737505) get unwanted pregnancy kit Riyadh
 
Switzerland Constitution 2002.pdf.........
Switzerland Constitution 2002.pdf.........Switzerland Constitution 2002.pdf.........
Switzerland Constitution 2002.pdf.........
 
怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制
怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制
怎样办理纽约州立大学宾汉姆顿分校毕业证(SUNY-Bin毕业证书)成绩单学校原版复制
 
怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制
怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制
怎样办理旧金山城市学院毕业证(CCSF毕业证书)成绩单学校原版复制
 
+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...
+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...
+97470301568>>weed for sale in qatar ,weed for sale in dubai,weed for sale in...
 
Digital Advertising Lecture for Advanced Digital & Social Media Strategy at U...
Digital Advertising Lecture for Advanced Digital & Social Media Strategy at U...Digital Advertising Lecture for Advanced Digital & Social Media Strategy at U...
Digital Advertising Lecture for Advanced Digital & Social Media Strategy at U...
 
Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...
Top profile Call Girls In Hapur [ 7014168258 ] Call Me For Genuine Models We ...
 
Abortion pills in Doha Qatar (+966572737505 ! Get Cytotec
Abortion pills in Doha Qatar (+966572737505 ! Get CytotecAbortion pills in Doha Qatar (+966572737505 ! Get Cytotec
Abortion pills in Doha Qatar (+966572737505 ! Get Cytotec
 
Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...
Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...
Top profile Call Girls In Bihar Sharif [ 7014168258 ] Call Me For Genuine Mod...
 
Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...
Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...
Top profile Call Girls In Purnia [ 7014168258 ] Call Me For Genuine Models We...
 

Apache Spark Architecture

Editor's Notes

  1. def printfunc (x): print 'Word "%s" occurs %d times' % (x[0], x[1]) infile = sc.textFile('hdfs://sparkdemo:8020/sparkdemo/textfiles/README.md', 4) rdd1 = infile.flatMap(lambda x: x.split()) rdd2 = rdd1.map(lambda x: (x, 1)).reduceByKey(lambda x, y: x+y) print rdd2.toDebugString() rdd2.foreach(printfunc)