Lightning-Fast Cluster Computing
with Spark and Shark
Mayuresh Kunjir and Harold Lim
Duke University
Outline
• Spark
– Spark Overview
– Components
– Life of a Job
– Spark Deployment
• Shark
– Motivation
– Architecture
• Results and Live Demo
Spark Overview
• Open source cluster computing system that aims
to make data analytics fast
– Supports diverse workloads
– sub-second latency
– fault tolerance
– Simplicity
• Research Paper: Resilient Distributed Datasets: A
Fault-Tolerant Abstraction for In-Memory Cluster
Computing [Zaharia et al., NSDI 2012]
Small Codebase
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
Hadoop I/O:
400 LOC
Mesos backend:
700 LOC
Standalone backend:
1700 LOC
Interpreter:
3300 LOC
Spark core: 16,000 LOC
Operators: 2000
Block manager: 2700
Scheduler: 2500
Networking: 1200
Accumulators: 200 Broadcast: 3500
Components
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
sc = new SparkContext
f = sc.textFile(“…”)
f.filter(…)
.count()
...
Your program
Spark client
(app master) Spark worker
HDFS, HBase, …
Block
manager
Task
threads
RDD graph
Scheduler
Block tracker
Shuffle tracker
Cluster
manager
Spark Program
• Can be written using Scala, Java, or Python.
• Spark includes spark-shell to run spark
interactively
• There is also a higher-level abstraction called
Shark (explained in the 2nd half of talk) that
exposes HiveQL language and compiles down to
Spark program
• Latest release of Spark can be downloaded from
spark-project.org/downloads.
– Includes examples, e.g., K-means, logistic regression,
alternating least squares matrix factorization, etc
RDD
• A Spark program revolves around the concept
of resilient distributed datasets (RDD)
– Fault-tolerant collection of elements that can be
operated on in parallel
– Perform operations on RDD
• Transformations (e.g., map, flatMap, union, filter, etc)
that creates new RDD
• Actions returns a value to the driver program (e.g.,
collect, count, etc)
Example Program
• val sc = new SparkContext(
“spark://...”, “MyJob”, home, jars)
val file = sc.textFile(“hdfs://...”)
val errors = file.filter(_.contains(“ERROR”))
errors.cache()
errors.count()
Resilient distributed
datasets (RDDs)
Action
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
RDD Graph
• First run: data not in
cache, so use
HadoopRDD’s locality
prefs (from HDFS)
• Second run: FilteredRDD
is in cache, so use its
locations
• If something falls out of
cache, go back to HDFS
HadoopRDD
path = hdfs://...
FilteredRDD
func = _.contains(…)
shouldCache = true
file:
errors:
Dataset-level view:
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
Scheduling Process
rdd1.join(rdd2)
.groupBy(…)
.filter(…)
RDD Objects
build operator DAG
agnostic to
operators!
doesn’t know
about stages
DAGScheduler
split graph into
stages of tasks
submit each
stage as ready
DAG
TaskScheduler
TaskSet
launch tasks via
cluster manager
retry failed or
straggling tasks
Cluster
manager
Worker
execute tasks
store and serve
blocks
Block
manager
Threads
Task
stage
failed
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
RDD Abstractions
• Extensible (Can implement new RDD operations,
e.g., to read from different sources)
• The current implemented RDD operations can
support a wide-range of workloads
• The RDD Interface
– Set of partitions (“splits”)
– List of dependencies on parent RDDs
– Function to compute a partition given parents
– Optional preferred locations
– Optional partitioning info (Partitioner)
Example: JoinedRDD
• partitions = one per reduce task
• dependencies = “shuffle” on each parent
• compute(partition) = read and join shuffled
data
• preferredLocations(part) = none
• partitioner = HashPartitioner(numTasks)
Spark will now know
this data is hashed!
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
Dependency Types
• Unlike Hadoop, supports a wide range of
dependency between operations
union
groupByKey
join with inputs
not co-partitioned
join with
inputs co-
partitioned
map, filter
“Narrow” deps: “Wide” (shuffle) deps:
DAG Scheduler Optimizations
Pipelines narrow ops.
within a stage
Picks join algorithms
based on partitioning
(minimize shuffles)
Reuses previously
cached data join
union
groupBy
map
Stage 3
Stage 1
Stage 2
A: B:
C: D:
E:
F:
G:
= previously computed partition
Task
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
Task Details
• Each Task object is self-contained
– Contains all transformation code up to input
boundary (e.g. HadoopRDD => filter => map)
• Allows Tasks on cached data even if they fall out
of cache
Design goal: any Task can run on any node
Only way a Task can fail is lost map output files
• Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
TaskScheduler Details
• Can run multiple concurrent TaskSets (Stages),
but currently does so in FIFO order
– Would be really easy to plug in other policies!
• Responsible for scheduling and launching
tasks on Worker nodes
• We (Duke) have implemented a Fair Scheduler
Worker
• Implemented by the Executor class
• Receives self-contained Task objects and calls run() on
them in a thread pool
• Tasks share the same JVM, which allows launching new
tasks quickly
• Has a BlockManager for serving shuffle data and
cachedRDDs (uses the same JVM memory space)
• CachedRDD are configurable
– can be stored as Java object (no
serialization/deserialization overhead) or Serialized
objects.
– Whether to spill to disk or recompute partitions from
parent RDDs when data fall out of cache
– LRU eviction policy
Spark Deployment
• Spark with Mesos (fine-grained)
– Incubator.apache.org/mesos
– Mesos offers resources to Spark programs (using
some configurable policy)
– Each spark tasks run as separate Mesos tasks
• Spark with Mesos (Coarse-grained)
– Only 1 Mesos task is launched on each machine
– Mesos Tasks are long-running and released after
program has completed
– Spark program bypasses Mesos scheduler and
dynamically schedules spark tasks on Mesos tasks (can
schedule more spark tasks on a Mesos task)
Spark Deployment
• Spark Stand-alone Mode
– Similar to Mesos Coarse-grained mode
– No need to have Mesos running on the cluster
• Spark with YARN (NextGen Hadoop)
– Requests pre-defined number of resource
containers from YARN
– Holds on to resource containers until the entire
Spark program finishes
– Spark schedules which tasks gets run on the
obtained resource containers
Another Example Spark Programval sc = new SparkContext(args(0), "SparkLocalKMeans",home,jars)
val lines = sc.textFile(args(1))
val data = lines.map(parseVector _).cache()
val K = args(2).toInt
val convergeDist = args(3).toDouble
var kPoints = data.takeSample(false, K, 42).toArray
var tempDist = 1.0
while(tempDist > convergeDist) {
var closest = data.map (p => (closestPoint(p, kPoints), (p, 1)))
var pointStats = closest.reduceByKey{case ((x1, y1), (x2, y2)) =>
(x1 + x2, y1 + y2)}
var newPoints = pointStats.map {pair =>
(pair._1, pair._2._1 / pair._2._2)}.collectAsMap()
tempDist = 0.0
for (i <- 0 until K) {
tempDist += kPoints(i).squaredDist(newPoints(i))
}
for (newP <- newPoints) {
kPoints(newP._1) = newP._2
}
println("Finished iteration (delta = " + tempDist + ")")
}
println("Final centers:")
kPoints.foreach(println)
Other Spark Features: Shared Variables
• Normally, Spark operations work on separate copies of all
variables
• Spark now has support for limited type of read-write
shared variables across tasks:
– Broadcast variables: Keep a read-only variable cached on each
machine (no need to ship a copy of variable with tasks)
• E.g., Give every node a copy of a large input dataset in efficient
manner
• Spark uses efficient broadcast algorithms
– Accumulators: variables that are only “added” to through an
associative operation.
• E.g., To implement counters or sums
• Tasks can add to the accumulator value and the driver program can
read the value
Some Issues
• RDDs cannot be shared across different Spark Programs
– Others have implemented a “server” program/shell that
maintains a long-lived SparkContext (Spark Program) and users
submits queries to this server
– Shark has a server mode
• Task operations can be memory-intensive and cause GC
problems
– Unlike Hadoop, task’s input are put into memory (e.g., grouping
is done using in-memory hash table)
• Base on experience, GC problems can result in poor
performance
– Have to ensure level of parallelism is high enough
– Ensure enough memory partition is set for tasks’ working set
(spark.storage.memoryFraction)
Outline
• Spark
– Spark Overview
– Components
– Life of a Job
– Spark Deployment
• Shark
– Motivation
– Architecture
• Results and Live Demo
Apache Hive
• Data warehouse over Hadoop developed at
Facebook
• SQL-like language, HiveQL interface to query
structured data on HDFS
• Queries compile to Hadoop MapReduce jobs
• Very popular: 90+% of Facebook Hadoop jobs
generated by Hive
Hive Architecture
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Hive Principles
• SQL provides a familiar interface for users
• Extensible types, functions, and storage
formats
• Horizontally scalable with high performance
on large datasets
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Hive Downsides
• Not interactive
– Hadoop startup latency is ~20 seconds, even for
small jobs
• No query locality
– If queries operate on the same subset of data,
they still run from scratch
– Reading data from disk is often bottleneck
• Requires separate machine learning dataflow
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Shark Motivations
• Data warehouses exhibit a huge amount of
temporal locality
– 90% of Facebook queries could be served in RAM
• Can we keep all the benefits of Hive
(scalability and extensibility) and exploit the
temporal locality?
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Hive
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Shark
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Introducing Shark
• Shark = Spark +
Hive
• Run HiveQL queries through Spark with Hive
UDF, UDAF, SerDe
• Utilize Spark’s in-memory RDD caching and
flexible language capabilities
• Integrates with Spark for machine learning
operations
Borrowed from Spark User Meetup, February 2012, “Shark – Hive on Spark”
Caching Data in Shark
• Creates a table cached in a cluster’s memory using
RDD.cache()
CREATE TABLE mytable_cached AS SELECT *
from mytable WHERE count > 10;
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Example: Log Mining
• Load error messages from a log into memory, then
interactively search for various patterns
Spark: lines = spark.textFile(“hdfs://...”)
errors = lines.filter(_.startsWith(“ERROR”))
messages = errors.map(_.split(‘t’)(1))
messages.cache()
messages.filter(_.contains(“foo”)).count
messages.filter(_.contains(“bar”)).count
CREATE TABLE log(header string, message string) ROW FORMAT
DELIMITED FIELDS TERMINATED BY ‘t’ LOCATION “hdfs://...”;
CREATE TABLE errors_cached AS SELECT message FROM log WHERE
header == “ERROR”;
SELECT count(*) FROM errors_cached WHERE message LIKE “%foo%”;
SELECT count(*) FROM errors_cached WHERE message LIKE “%bar%”;
Shark:
Borrowed from Spark User Meetup, February 2012, “Shark – Hive on Spark”
Data Model
• Tables: unit of data with the same schema
• Partitions: e.g. range-partition tables by date
• Buckets: hash partitions within partitions
– not yet supported in Shark
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Data Types
• Primitive types
– TINYINT, SMALLINT, INT, BIGINT
– BOOLEAN
– FLOAT, DOUBLE
– STRING
• Complex types
– Structs: STRUCT {a INT; b INT}
– Arrays: [‘a’, ‘b’, ‘c’]
– Maps (key-value pairs): M[‘key’]
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
HiveQL
• Subset of SQL
– Projection, Selection
– Group-by and aggregations
– Sort by and order by
– Joins
– Sub queries, unions
• Hive-specific
– Supports custom map/reduce scripts (TRANSFORM)
– Hints for performance optimizations
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Performance Optimizations
• Caching data in-memory
• Hash-based shuffles for group-by
• Push-down of limits
• Join optimizations through Partial DAG
Execution
• Columnar memory storage
Caching
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Sort, limit, hash shuffle
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Outline
• Spark
– Spark Overview
– Components
– Life of a Job
– Spark Deployment
• Shark
– Motivation
– Architecture
• Results and Live Demo
TPC-H Data
• 5 node cluster running Hive 0.9 and Shark 0.2
• 50GB data on HDFS
• Data read as Hive external tables
Hive versus Shark
Query On Hive On Shark (disk)
1 0:06:10 0:02:20
2 0:10:00 0:07:30
3 0:14:00 0:05:10
4 0:11:40 0:04:30
5 0:17:30 0:07:20
6 0:03:10 0:01:35
7 0:29:10 0:17:40
8 0:19:10 0:09:50
9 0:48:20 0:19:45
10 0:15:00 0:03:50
11 0:07:30 0:02:00
12 0:10:30 0:06:20
13 0:10:00 0:04:00
14 0:05:35 0:01:50
15 0:07:30 0:01:40
16 0:12:50 0:04:50
17 0:20:00 0:10:30
18 0:30:00 0:17:10
19 0:11:40 0:07:05
20 0:15:00 0:04:10
21 0:36:40 0:19:15
22 0:10:10 0:03:40
Number of reducers
have to be explicitly
set in Shark
Performance Tuning
• Two parameters that can significantly affect
performance:
1. Setting the number of reducers
2. Map-side aggregation
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Number of Reducers
• SET mapred.reduce.tasks = 50;
• Shark relies on Spark to infer the number of
map tasks (automatically based on input size)
• Number of reduce tasks need to be specified
by the user
• Out of memory error on slaves if num too
small
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Map-side Aggregation
• SET hive.map.aggr = TRUE;
• Aggregation functions are algebraic and can
be applied on mappers to reduce shuffle data
• Each mapper builds a hash-table to do the first
–level aggregation
Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
Possible Improvements
• Caching is currently explicitly set
– Can this be set automatically?
• Multi-query optimization
– What to cache?
• Treating workload as a sequence
– When to cache?
– When to run a query?
• Notion of Fairness
– Is the notion of Hadoop fairness still valid, given that Spark can also
utilize memory (cached RDD) resources?
• Better support for Multi-tenancy?
– Spark was originally designed/implemented to have each user
workload as separate Spark program
– However, RDDs can’t be shared across different Spark Programs
– Current workaround: Have a single Spark program server and
implement a fair task scheduler
– Is this good enough?
Useful Links
• Project home pages
– http://spark-project.org/
– http://shark.cs.berkeley.edu/
• Research Papers
– Resilient Distributed Datasets: A Fault-Tolerant Abstraction for
In-Memory Cluster Computing. Matei Zaharia, Mosharaf
Chowdhury, Tathagata Das, Ankur Dave, Justin Ma, Murphy
McCauley, Michael J. Franklin, Scott Shenker, Ion Stoica. NSDI
2012. April 2012.
– Shark: SQL and Rich Analytics at Scale. Reynold Xin, Joshua
Rosen, Matei Zaharia, Michael J. Franklin, Scott Shenker, Ion
Stoica. Technical Report UCB/EECS-2012-214. November 2012.
• AMP Camp – Big Data Bootcamp
– http://ampcamp.berkeley.edu/amp-camp-one-berkeley-2012/
Questions?
Thank you!
• mayuresh@cs.duke.edu
• harold@cs.duke.edu

TriHUG talk on Spark and Shark

  • 1.
    Lightning-Fast Cluster Computing withSpark and Shark Mayuresh Kunjir and Harold Lim Duke University
  • 2.
    Outline • Spark – SparkOverview – Components – Life of a Job – Spark Deployment • Shark – Motivation – Architecture • Results and Live Demo
  • 3.
    Spark Overview • Opensource cluster computing system that aims to make data analytics fast – Supports diverse workloads – sub-second latency – fault tolerance – Simplicity • Research Paper: Resilient Distributed Datasets: A Fault-Tolerant Abstraction for In-Memory Cluster Computing [Zaharia et al., NSDI 2012]
  • 4.
    Small Codebase • Borrowedfrom Spark User Meetup 2012, Introduction to Spark Internals Hadoop I/O: 400 LOC Mesos backend: 700 LOC Standalone backend: 1700 LOC Interpreter: 3300 LOC Spark core: 16,000 LOC Operators: 2000 Block manager: 2700 Scheduler: 2500 Networking: 1200 Accumulators: 200 Broadcast: 3500
  • 5.
    Components • Borrowed fromSpark User Meetup 2012, Introduction to Spark Internals sc = new SparkContext f = sc.textFile(“…”) f.filter(…) .count() ... Your program Spark client (app master) Spark worker HDFS, HBase, … Block manager Task threads RDD graph Scheduler Block tracker Shuffle tracker Cluster manager
  • 6.
    Spark Program • Canbe written using Scala, Java, or Python. • Spark includes spark-shell to run spark interactively • There is also a higher-level abstraction called Shark (explained in the 2nd half of talk) that exposes HiveQL language and compiles down to Spark program • Latest release of Spark can be downloaded from spark-project.org/downloads. – Includes examples, e.g., K-means, logistic regression, alternating least squares matrix factorization, etc
  • 7.
    RDD • A Sparkprogram revolves around the concept of resilient distributed datasets (RDD) – Fault-tolerant collection of elements that can be operated on in parallel – Perform operations on RDD • Transformations (e.g., map, flatMap, union, filter, etc) that creates new RDD • Actions returns a value to the driver program (e.g., collect, count, etc)
  • 8.
    Example Program • valsc = new SparkContext( “spark://...”, “MyJob”, home, jars) val file = sc.textFile(“hdfs://...”) val errors = file.filter(_.contains(“ERROR”)) errors.cache() errors.count() Resilient distributed datasets (RDDs) Action • Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
  • 9.
    RDD Graph • Firstrun: data not in cache, so use HadoopRDD’s locality prefs (from HDFS) • Second run: FilteredRDD is in cache, so use its locations • If something falls out of cache, go back to HDFS HadoopRDD path = hdfs://... FilteredRDD func = _.contains(…) shouldCache = true file: errors: Dataset-level view: • Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
  • 10.
    Scheduling Process rdd1.join(rdd2) .groupBy(…) .filter(…) RDD Objects buildoperator DAG agnostic to operators! doesn’t know about stages DAGScheduler split graph into stages of tasks submit each stage as ready DAG TaskScheduler TaskSet launch tasks via cluster manager retry failed or straggling tasks Cluster manager Worker execute tasks store and serve blocks Block manager Threads Task stage failed • Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
  • 11.
    RDD Abstractions • Extensible(Can implement new RDD operations, e.g., to read from different sources) • The current implemented RDD operations can support a wide-range of workloads • The RDD Interface – Set of partitions (“splits”) – List of dependencies on parent RDDs – Function to compute a partition given parents – Optional preferred locations – Optional partitioning info (Partitioner)
  • 12.
    Example: JoinedRDD • partitions= one per reduce task • dependencies = “shuffle” on each parent • compute(partition) = read and join shuffled data • preferredLocations(part) = none • partitioner = HashPartitioner(numTasks) Spark will now know this data is hashed! • Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
  • 13.
    Dependency Types • UnlikeHadoop, supports a wide range of dependency between operations union groupByKey join with inputs not co-partitioned join with inputs co- partitioned map, filter “Narrow” deps: “Wide” (shuffle) deps:
  • 14.
    DAG Scheduler Optimizations Pipelinesnarrow ops. within a stage Picks join algorithms based on partitioning (minimize shuffles) Reuses previously cached data join union groupBy map Stage 3 Stage 1 Stage 2 A: B: C: D: E: F: G: = previously computed partition Task • Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
  • 15.
    Task Details • EachTask object is self-contained – Contains all transformation code up to input boundary (e.g. HadoopRDD => filter => map) • Allows Tasks on cached data even if they fall out of cache Design goal: any Task can run on any node Only way a Task can fail is lost map output files • Borrowed from Spark User Meetup 2012, Introduction to Spark Internals
  • 16.
    TaskScheduler Details • Canrun multiple concurrent TaskSets (Stages), but currently does so in FIFO order – Would be really easy to plug in other policies! • Responsible for scheduling and launching tasks on Worker nodes • We (Duke) have implemented a Fair Scheduler
  • 17.
    Worker • Implemented bythe Executor class • Receives self-contained Task objects and calls run() on them in a thread pool • Tasks share the same JVM, which allows launching new tasks quickly • Has a BlockManager for serving shuffle data and cachedRDDs (uses the same JVM memory space) • CachedRDD are configurable – can be stored as Java object (no serialization/deserialization overhead) or Serialized objects. – Whether to spill to disk or recompute partitions from parent RDDs when data fall out of cache – LRU eviction policy
  • 18.
    Spark Deployment • Sparkwith Mesos (fine-grained) – Incubator.apache.org/mesos – Mesos offers resources to Spark programs (using some configurable policy) – Each spark tasks run as separate Mesos tasks • Spark with Mesos (Coarse-grained) – Only 1 Mesos task is launched on each machine – Mesos Tasks are long-running and released after program has completed – Spark program bypasses Mesos scheduler and dynamically schedules spark tasks on Mesos tasks (can schedule more spark tasks on a Mesos task)
  • 19.
    Spark Deployment • SparkStand-alone Mode – Similar to Mesos Coarse-grained mode – No need to have Mesos running on the cluster • Spark with YARN (NextGen Hadoop) – Requests pre-defined number of resource containers from YARN – Holds on to resource containers until the entire Spark program finishes – Spark schedules which tasks gets run on the obtained resource containers
  • 20.
    Another Example SparkProgramval sc = new SparkContext(args(0), "SparkLocalKMeans",home,jars) val lines = sc.textFile(args(1)) val data = lines.map(parseVector _).cache() val K = args(2).toInt val convergeDist = args(3).toDouble var kPoints = data.takeSample(false, K, 42).toArray var tempDist = 1.0 while(tempDist > convergeDist) { var closest = data.map (p => (closestPoint(p, kPoints), (p, 1))) var pointStats = closest.reduceByKey{case ((x1, y1), (x2, y2)) => (x1 + x2, y1 + y2)} var newPoints = pointStats.map {pair => (pair._1, pair._2._1 / pair._2._2)}.collectAsMap() tempDist = 0.0 for (i <- 0 until K) { tempDist += kPoints(i).squaredDist(newPoints(i)) } for (newP <- newPoints) { kPoints(newP._1) = newP._2 } println("Finished iteration (delta = " + tempDist + ")") } println("Final centers:") kPoints.foreach(println)
  • 21.
    Other Spark Features:Shared Variables • Normally, Spark operations work on separate copies of all variables • Spark now has support for limited type of read-write shared variables across tasks: – Broadcast variables: Keep a read-only variable cached on each machine (no need to ship a copy of variable with tasks) • E.g., Give every node a copy of a large input dataset in efficient manner • Spark uses efficient broadcast algorithms – Accumulators: variables that are only “added” to through an associative operation. • E.g., To implement counters or sums • Tasks can add to the accumulator value and the driver program can read the value
  • 22.
    Some Issues • RDDscannot be shared across different Spark Programs – Others have implemented a “server” program/shell that maintains a long-lived SparkContext (Spark Program) and users submits queries to this server – Shark has a server mode • Task operations can be memory-intensive and cause GC problems – Unlike Hadoop, task’s input are put into memory (e.g., grouping is done using in-memory hash table) • Base on experience, GC problems can result in poor performance – Have to ensure level of parallelism is high enough – Ensure enough memory partition is set for tasks’ working set (spark.storage.memoryFraction)
  • 23.
    Outline • Spark – SparkOverview – Components – Life of a Job – Spark Deployment • Shark – Motivation – Architecture • Results and Live Demo
  • 24.
    Apache Hive • Datawarehouse over Hadoop developed at Facebook • SQL-like language, HiveQL interface to query structured data on HDFS • Queries compile to Hadoop MapReduce jobs • Very popular: 90+% of Facebook Hadoop jobs generated by Hive
  • 25.
    Hive Architecture Borrowed fromAMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 26.
    Hive Principles • SQLprovides a familiar interface for users • Extensible types, functions, and storage formats • Horizontally scalable with high performance on large datasets Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 27.
    Hive Downsides • Notinteractive – Hadoop startup latency is ~20 seconds, even for small jobs • No query locality – If queries operate on the same subset of data, they still run from scratch – Reading data from disk is often bottleneck • Requires separate machine learning dataflow Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 28.
    Shark Motivations • Datawarehouses exhibit a huge amount of temporal locality – 90% of Facebook queries could be served in RAM • Can we keep all the benefits of Hive (scalability and extensibility) and exploit the temporal locality? Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 29.
    Hive Borrowed from AMPCamp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 30.
    Shark Borrowed from AMPCamp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 31.
    Introducing Shark • Shark= Spark + Hive • Run HiveQL queries through Spark with Hive UDF, UDAF, SerDe • Utilize Spark’s in-memory RDD caching and flexible language capabilities • Integrates with Spark for machine learning operations Borrowed from Spark User Meetup, February 2012, “Shark – Hive on Spark”
  • 32.
    Caching Data inShark • Creates a table cached in a cluster’s memory using RDD.cache() CREATE TABLE mytable_cached AS SELECT * from mytable WHERE count > 10; Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 33.
    Example: Log Mining •Load error messages from a log into memory, then interactively search for various patterns Spark: lines = spark.textFile(“hdfs://...”) errors = lines.filter(_.startsWith(“ERROR”)) messages = errors.map(_.split(‘t’)(1)) messages.cache() messages.filter(_.contains(“foo”)).count messages.filter(_.contains(“bar”)).count CREATE TABLE log(header string, message string) ROW FORMAT DELIMITED FIELDS TERMINATED BY ‘t’ LOCATION “hdfs://...”; CREATE TABLE errors_cached AS SELECT message FROM log WHERE header == “ERROR”; SELECT count(*) FROM errors_cached WHERE message LIKE “%foo%”; SELECT count(*) FROM errors_cached WHERE message LIKE “%bar%”; Shark: Borrowed from Spark User Meetup, February 2012, “Shark – Hive on Spark”
  • 34.
    Data Model • Tables:unit of data with the same schema • Partitions: e.g. range-partition tables by date • Buckets: hash partitions within partitions – not yet supported in Shark Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 35.
    Data Types • Primitivetypes – TINYINT, SMALLINT, INT, BIGINT – BOOLEAN – FLOAT, DOUBLE – STRING • Complex types – Structs: STRUCT {a INT; b INT} – Arrays: [‘a’, ‘b’, ‘c’] – Maps (key-value pairs): M[‘key’] Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 36.
    HiveQL • Subset ofSQL – Projection, Selection – Group-by and aggregations – Sort by and order by – Joins – Sub queries, unions • Hive-specific – Supports custom map/reduce scripts (TRANSFORM) – Hints for performance optimizations Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 37.
    Performance Optimizations • Cachingdata in-memory • Hash-based shuffles for group-by • Push-down of limits • Join optimizations through Partial DAG Execution • Columnar memory storage
  • 38.
    Caching Borrowed from AMPCamp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 39.
    Sort, limit, hashshuffle Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 40.
    Outline • Spark – SparkOverview – Components – Life of a Job – Spark Deployment • Shark – Motivation – Architecture • Results and Live Demo
  • 41.
    TPC-H Data • 5node cluster running Hive 0.9 and Shark 0.2 • 50GB data on HDFS • Data read as Hive external tables
  • 42.
    Hive versus Shark QueryOn Hive On Shark (disk) 1 0:06:10 0:02:20 2 0:10:00 0:07:30 3 0:14:00 0:05:10 4 0:11:40 0:04:30 5 0:17:30 0:07:20 6 0:03:10 0:01:35 7 0:29:10 0:17:40 8 0:19:10 0:09:50 9 0:48:20 0:19:45 10 0:15:00 0:03:50 11 0:07:30 0:02:00 12 0:10:30 0:06:20 13 0:10:00 0:04:00 14 0:05:35 0:01:50 15 0:07:30 0:01:40 16 0:12:50 0:04:50 17 0:20:00 0:10:30 18 0:30:00 0:17:10 19 0:11:40 0:07:05 20 0:15:00 0:04:10 21 0:36:40 0:19:15 22 0:10:10 0:03:40 Number of reducers have to be explicitly set in Shark
  • 43.
    Performance Tuning • Twoparameters that can significantly affect performance: 1. Setting the number of reducers 2. Map-side aggregation Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 44.
    Number of Reducers •SET mapred.reduce.tasks = 50; • Shark relies on Spark to infer the number of map tasks (automatically based on input size) • Number of reduce tasks need to be specified by the user • Out of memory error on slaves if num too small Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 45.
    Map-side Aggregation • SEThive.map.aggr = TRUE; • Aggregation functions are algebraic and can be applied on mappers to reduce shuffle data • Each mapper builds a hash-table to do the first –level aggregation Borrowed from AMP Camp One – Big Data Bootcamp Berkeley, August 2012, “Structured Data with Hive and Shark”
  • 46.
    Possible Improvements • Cachingis currently explicitly set – Can this be set automatically? • Multi-query optimization – What to cache? • Treating workload as a sequence – When to cache? – When to run a query? • Notion of Fairness – Is the notion of Hadoop fairness still valid, given that Spark can also utilize memory (cached RDD) resources? • Better support for Multi-tenancy? – Spark was originally designed/implemented to have each user workload as separate Spark program – However, RDDs can’t be shared across different Spark Programs – Current workaround: Have a single Spark program server and implement a fair task scheduler – Is this good enough?
  • 47.
    Useful Links • Projecthome pages – http://spark-project.org/ – http://shark.cs.berkeley.edu/ • Research Papers – Resilient Distributed Datasets: A Fault-Tolerant Abstraction for In-Memory Cluster Computing. Matei Zaharia, Mosharaf Chowdhury, Tathagata Das, Ankur Dave, Justin Ma, Murphy McCauley, Michael J. Franklin, Scott Shenker, Ion Stoica. NSDI 2012. April 2012. – Shark: SQL and Rich Analytics at Scale. Reynold Xin, Joshua Rosen, Matei Zaharia, Michael J. Franklin, Scott Shenker, Ion Stoica. Technical Report UCB/EECS-2012-214. November 2012. • AMP Camp – Big Data Bootcamp – http://ampcamp.berkeley.edu/amp-camp-one-berkeley-2012/
  • 48.