|
|||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use PTable | |
---|---|
org.apache.crunch | Client-facing API and core abstractions. |
org.apache.crunch.contrib.text | |
org.apache.crunch.examples | Example applications demonstrating various aspects of Crunch. |
org.apache.crunch.impl.dist | |
org.apache.crunch.impl.dist.collect | |
org.apache.crunch.impl.mem | In-memory Pipeline implementation for rapid prototyping and testing. |
org.apache.crunch.impl.spark | |
org.apache.crunch.impl.spark.collect | |
org.apache.crunch.lib | Joining, sorting, aggregating, and other commonly used functionality. |
org.apache.crunch.lib.join | Inner and outer joins on collections. |
org.apache.crunch.util | An assorted set of utilities. |
Uses of PTable in org.apache.crunch |
---|
Methods in org.apache.crunch that return PTable | ||
---|---|---|
PTable<K,V> |
PTable.bottom(int count)
Returns a PTable made up of the pairs in this PTable with the smallest value field. |
|
|
PCollection.by(MapFn<S,K> extractKeyFn,
PType<K> keyType)
Apply the given map function to each element of this instance in order to create a PTable . |
|
|
PCollection.by(String name,
MapFn<S,K> extractKeyFn,
PType<K> keyType)
Apply the given map function to each element of this instance in order to create a PTable . |
|
PTable<K,V> |
PTable.cache()
|
|
PTable<K,V> |
PTable.cache(CachingOptions options)
|
|
|
PTable.cogroup(PTable<K,U> other)
Co-group operation with the given table on common keys. |
|
PTable<K,Collection<V>> |
PTable.collectValues()
Aggregate all of the values with the same key into a single key-value pair in the returned PTable. |
|
PTable<K,V> |
PGroupedTable.combineValues(Aggregator<V> aggregator)
Combine the values in each group using the given Aggregator . |
|
PTable<K,V> |
PGroupedTable.combineValues(Aggregator<V> combineAggregator,
Aggregator<V> reduceAggregator)
Combine and reduces the values in each group using the given Aggregator instances. |
|
PTable<K,V> |
PGroupedTable.combineValues(CombineFn<K,V> combineFn)
Combines the values of this grouping using the given CombineFn . |
|
PTable<K,V> |
PGroupedTable.combineValues(CombineFn<K,V> combineFn,
CombineFn<K,V> reduceFn)
Combines and reduces the values of this grouping using the given CombineFn instances. |
|
PTable<S,Long> |
PCollection.count()
Returns a PTable instance that contains the counts of each unique
element of this PCollection. |
|
|
Pipeline.emptyPTable(PTableType<K,V> ptype)
|
|
PTable<K,V> |
PTable.filter(FilterFn<Pair<K,V>> filterFn)
Apply the given filter function to this instance and return the resulting PTable . |
|
PTable<K,V> |
PTable.filter(String name,
FilterFn<Pair<K,V>> filterFn)
Apply the given filter function to this instance and return the resulting PTable . |
|
|
PTable.join(PTable<K,U> other)
Perform an inner join on this table and the one passed in as an argument on their common keys. |
|
|
PTable.mapKeys(MapFn<K,K2> mapFn,
PType<K2> ptype)
Returns a PTable that has the same values as this instance, but
uses the given function to map the keys. |
|
|
PTable.mapKeys(String name,
MapFn<K,K2> mapFn,
PType<K2> ptype)
Returns a PTable that has the same values as this instance, but
uses the given function to map the keys. |
|
|
PGroupedTable.mapValues(MapFn<Iterable<V>,U> mapFn,
PType<U> ptype)
Maps the Iterable<V> elements of each record to a new type. |
|
|
PTable.mapValues(MapFn<V,U> mapFn,
PType<U> ptype)
Returns a PTable that has the same keys as this instance, but
uses the given function to map the values. |
|
|
PGroupedTable.mapValues(String name,
MapFn<Iterable<V>,U> mapFn,
PType<U> ptype)
Maps the Iterable<V> elements of each record to a new type. |
|
|
PTable.mapValues(String name,
MapFn<V,U> mapFn,
PType<U> ptype)
Returns a PTable that has the same keys as this instance, but
uses the given function to map the values. |
|
|
PCollection.parallelDo(DoFn<S,Pair<K,V>> doFn,
PTableType<K,V> type)
Similar to the other parallelDo instance, but returns a
PTable instance instead of a PCollection . |
|
|
PCollection.parallelDo(String name,
DoFn<S,Pair<K,V>> doFn,
PTableType<K,V> type)
Similar to the other parallelDo instance, but returns a
PTable instance instead of a PCollection . |
|
|
PCollection.parallelDo(String name,
DoFn<S,Pair<K,V>> doFn,
PTableType<K,V> type,
ParallelDoOptions options)
Similar to the other parallelDo instance, but returns a
PTable instance instead of a PCollection . |
|
|
Pipeline.read(TableSource<K,V> tableSource)
A version of the read method for TableSource instances that map to
PTable s. |
|
PTable<K,V> |
PTable.top(int count)
Returns a PTable made up of the pairs in this PTable with the largest value field. |
|
PTable<K,V> |
PGroupedTable.ungroup()
Convert this grouping back into a multimap. |
|
PTable<K,V> |
PTable.union(PTable<K,V>... others)
Returns a PTable instance that acts as the union of this
PTable and the input PTable s. |
|
PTable<K,V> |
PTable.union(PTable<K,V> other)
Returns a PTable instance that acts as the union of this
PTable and the other PTable s. |
|
PTable<K,V> |
PTable.write(Target target)
Writes this PTable to the given Target . |
|
PTable<K,V> |
PTable.write(Target target,
Target.WriteMode writeMode)
Writes this PTable to the given Target , using the
given Target.WriteMode to handle existing targets. |
Methods in org.apache.crunch with parameters of type PTable | ||
---|---|---|
|
PTable.cogroup(PTable<K,U> other)
Co-group operation with the given table on common keys. |
|
|
PTable.join(PTable<K,U> other)
Perform an inner join on this table and the one passed in as an argument on their common keys. |
|
PTable<K,V> |
PTable.union(PTable<K,V>... others)
Returns a PTable instance that acts as the union of this
PTable and the input PTable s. |
|
PTable<K,V> |
PTable.union(PTable<K,V> other)
Returns a PTable instance that acts as the union of this
PTable and the other PTable s. |
Uses of PTable in org.apache.crunch.contrib.text |
---|
Methods in org.apache.crunch.contrib.text that return PTable | ||
---|---|---|
static
|
Parse.parseTable(String groupName,
PCollection<String> input,
Extractor<Pair<K,V>> extractor)
Parses the lines of the input PCollection<String> and returns a PTable<K, V> using
the given Extractor<Pair<K, V>> . |
|
static
|
Parse.parseTable(String groupName,
PCollection<String> input,
PTypeFamily ptf,
Extractor<Pair<K,V>> extractor)
Parses the lines of the input PCollection<String> and returns a PTable<K, V> using
the given Extractor<Pair<K, V>> that uses the given PTypeFamily . |
Uses of PTable in org.apache.crunch.examples |
---|
Methods in org.apache.crunch.examples that return PTable | |
---|---|
PTable<String,String> |
WordAggregationHBase.extractText(PTable<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Result> words)
Extract information from hbase |
Methods in org.apache.crunch.examples with parameters of type PTable | |
---|---|
PCollection<org.apache.hadoop.hbase.client.Put> |
WordAggregationHBase.createPut(PTable<String,String> extractedText)
Create puts in order to insert them in hbase. |
PTable<String,String> |
WordAggregationHBase.extractText(PTable<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.client.Result> words)
Extract information from hbase |
Uses of PTable in org.apache.crunch.impl.dist |
---|
Methods in org.apache.crunch.impl.dist that return PTable | ||
---|---|---|
|
DistributedPipeline.emptyPTable(PTableType<K,V> ptype)
|
|
|
DistributedPipeline.read(TableSource<K,V> source)
|
Uses of PTable in org.apache.crunch.impl.dist.collect |
---|
Classes in org.apache.crunch.impl.dist.collect that implement PTable | |
---|---|
class |
BaseDoTable<K,V>
|
class |
BaseInputTable<K,V>
|
class |
BaseUnionTable<K,V>
|
class |
EmptyPTable<K,V>
|
class |
PTableBase<K,V>
|
Methods in org.apache.crunch.impl.dist.collect that return PTable | ||
---|---|---|
PTable<K,V> |
PTableBase.bottom(int count)
|
|
|
PCollectionImpl.by(MapFn<S,K> mapFn,
PType<K> keyType)
|
|
|
PCollectionImpl.by(String name,
MapFn<S,K> mapFn,
PType<K> keyType)
|
|
PTable<K,V> |
PTableBase.cache()
|
|
PTable<K,V> |
PTableBase.cache(CachingOptions options)
|
|
|
PTableBase.cogroup(PTable<K,U> other)
|
|
PTable<K,Collection<V>> |
PTableBase.collectValues()
|
|
PTable<K,V> |
BaseGroupedTable.combineValues(Aggregator<V> agg)
|
|
PTable<K,V> |
BaseGroupedTable.combineValues(Aggregator<V> combineAgg,
Aggregator<V> reduceAgg)
|
|
PTable<K,V> |
BaseGroupedTable.combineValues(CombineFn<K,V> combineFn)
|
|
PTable<K,V> |
BaseGroupedTable.combineValues(CombineFn<K,V> combineFn,
CombineFn<K,V> reduceFn)
|
|
PTable<S,Long> |
PCollectionImpl.count()
|
|
|
PCollectionFactory.createUnionTable(List<PTableBase<K,V>> internal)
|
|
PTable<K,V> |
PTableBase.filter(FilterFn<Pair<K,V>> filterFn)
|
|
PTable<K,V> |
PTableBase.filter(String name,
FilterFn<Pair<K,V>> filterFn)
|
|
|
PTableBase.join(PTable<K,U> other)
|
|
|
PTableBase.mapKeys(MapFn<K,K2> mapFn,
PType<K2> ptype)
|
|
|
PTableBase.mapKeys(String name,
MapFn<K,K2> mapFn,
PType<K2> ptype)
|
|
|
BaseGroupedTable.mapValues(MapFn<Iterable<V>,U> mapFn,
PType<U> ptype)
|
|
|
PTableBase.mapValues(MapFn<V,U> mapFn,
PType<U> ptype)
|
|
|
BaseGroupedTable.mapValues(String name,
MapFn<Iterable<V>,U> mapFn,
PType<U> ptype)
|
|
|
PTableBase.mapValues(String name,
MapFn<V,U> mapFn,
PType<U> ptype)
|
|
|
PCollectionImpl.parallelDo(DoFn<S,Pair<K,V>> fn,
PTableType<K,V> type)
|
|
|
PCollectionImpl.parallelDo(String name,
DoFn<S,Pair<K,V>> fn,
PTableType<K,V> type)
|
|
|
PCollectionImpl.parallelDo(String name,
DoFn<S,Pair<K,V>> fn,
PTableType<K,V> type,
ParallelDoOptions options)
|
|
PTable<K,V> |
PTableBase.top(int count)
|
|
PTable<K,V> |
BaseGroupedTable.ungroup()
|
|
PTable<K,V> |
PTableBase.union(PTable<K,V>... others)
|
|
PTable<K,V> |
PTableBase.union(PTable<K,V> other)
|
|
PTable<K,V> |
PTableBase.write(Target target)
|
|
PTable<K,V> |
PTableBase.write(Target target,
Target.WriteMode writeMode)
|
Methods in org.apache.crunch.impl.dist.collect with parameters of type PTable | ||
---|---|---|
|
PTableBase.cogroup(PTable<K,U> other)
|
|
|
PTableBase.join(PTable<K,U> other)
|
|
PTable<K,V> |
PTableBase.union(PTable<K,V>... others)
|
|
PTable<K,V> |
PTableBase.union(PTable<K,V> other)
|
Uses of PTable in org.apache.crunch.impl.mem |
---|
Methods in org.apache.crunch.impl.mem that return PTable | ||
---|---|---|
|
MemPipeline.emptyPTable(PTableType<K,V> ptype)
|
|
|
MemPipeline.read(TableSource<K,V> source)
|
|
static
|
MemPipeline.tableOf(Iterable<Pair<S,T>> pairs)
|
|
static
|
MemPipeline.tableOf(S s,
T t,
Object... more)
|
|
static
|
MemPipeline.typedTableOf(PTableType<S,T> ptype,
Iterable<Pair<S,T>> pairs)
|
|
static
|
MemPipeline.typedTableOf(PTableType<S,T> ptype,
S s,
T t,
Object... more)
|
Uses of PTable in org.apache.crunch.impl.spark |
---|
Methods in org.apache.crunch.impl.spark that return PTable | ||
---|---|---|
|
SparkPipeline.emptyPTable(PTableType<K,V> ptype)
|
Uses of PTable in org.apache.crunch.impl.spark.collect |
---|
Classes in org.apache.crunch.impl.spark.collect that implement PTable | |
---|---|
class |
DoTable<K,V>
|
class |
InputTable<K,V>
|
class |
UnionTable<K,V>
|
Methods in org.apache.crunch.impl.spark.collect that return PTable | ||
---|---|---|
|
SparkCollectFactory.createUnionTable(List<PTableBase<K,V>> internal)
|
Uses of PTable in org.apache.crunch.lib |
---|
Methods in org.apache.crunch.lib that return PTable | ||
---|---|---|
static
|
PTables.asPTable(PCollection<Pair<K,V>> pcollect)
Convert the given PCollection<Pair<K, V>> to a PTable<K, V> . |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,?> first,
PTable<K,?>... rest)
Co-groups an arbitrary number of PTable arguments with a user-specified degree of parallelism
(a.k.a, number of reducers.) The largest table should come last in the ordering. |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,U> left,
PTable<K,V> right)
Co-groups the two PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(PTable<K,?> first,
PTable<K,?>... rest)
Co-groups an arbitrary number of PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,U> left,
PTable<K,V> right)
Co-groups the two PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments. |
|
static
|
Aggregate.collectValues(PTable<K,V> collect)
|
|
static
|
Aggregate.count(PCollection<S> collect)
Returns a PTable that contains the unique elements of this collection mapped to a count
of their occurrences. |
|
static
|
Aggregate.count(PCollection<S> collect,
int numPartitions)
Returns a PTable that contains the unique elements of this collection mapped to a count
of their occurrences. |
|
static
|
Cartesian.cross(PTable<K1,U> left,
PTable<K2,V> right)
Performs a full cross join on the specified PTable s (using the same
strategy as Pig's CROSS operator). |
|
static
|
Cartesian.cross(PTable<K1,U> left,
PTable<K2,V> right,
int parallelism)
Performs a full cross join on the specified PTable s (using the same
strategy as Pig's CROSS operator). |
|
static
|
Distinct.distinct(PTable<K,V> input)
A PTable<K, V> analogue of the distinct function. |
|
static
|
Distinct.distinct(PTable<K,V> input,
int flushEvery)
A PTable<K, V> analogue of the distinct function. |
|
static
|
Join.fullJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a full outer join on the specified PTable s. |
|
static
|
Join.innerJoin(PTable<K,U> left,
PTable<K,V> right)
Performs an inner join on the specified PTable s. |
|
static
|
Join.join(PTable<K,U> left,
PTable<K,V> right)
Performs an inner join on the specified PTable s. |
|
static
|
Join.leftJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a left outer join on the specified PTable s. |
|
static
|
Mapreduce.map(PTable<K1,V1> input,
Class<? extends org.apache.hadoop.mapreduce.Mapper<K1,V1,K2,V2>> mapperClass,
Class<K2> keyClass,
Class<V2> valueClass)
|
|
static
|
Mapred.map(PTable<K1,V1> input,
Class<? extends org.apache.hadoop.mapred.Mapper<K1,V1,K2,V2>> mapperClass,
Class<K2> keyClass,
Class<V2> valueClass)
|
|
static
|
PTables.mapKeys(PTable<K1,V> ptable,
MapFn<K1,K2> mapFn,
PType<K2> ptype)
Maps a PTable<K1, V> to a PTable<K2, V> using the given MapFn<K1, K2> on
the keys of the PTable . |
|
static
|
PTables.mapKeys(String name,
PTable<K1,V> ptable,
MapFn<K1,K2> mapFn,
PType<K2> ptype)
Maps a PTable<K1, V> to a PTable<K2, V> using the given MapFn<K1, K2> on
the keys of the PTable . |
|
static
|
PTables.mapValues(PGroupedTable<K,U> ptable,
MapFn<Iterable<U>,V> mapFn,
PType<V> ptype)
An analogue of the mapValues function for PGroupedTable<K, U> collections. |
|
static
|
PTables.mapValues(PTable<K,U> ptable,
MapFn<U,V> mapFn,
PType<V> ptype)
Maps a PTable<K, U> to a PTable<K, V> using the given MapFn<U, V> on
the values of the PTable . |
|
static
|
PTables.mapValues(String name,
PGroupedTable<K,U> ptable,
MapFn<Iterable<U>,V> mapFn,
PType<V> ptype)
An analogue of the mapValues function for PGroupedTable<K, U> collections. |
|
static
|
PTables.mapValues(String name,
PTable<K,U> ptable,
MapFn<U,V> mapFn,
PType<V> ptype)
Maps a PTable<K, U> to a PTable<K, V> using the given MapFn<U, V> on
the values of the PTable . |
|
static
|
Mapreduce.reduce(PGroupedTable<K1,V1> input,
Class<? extends org.apache.hadoop.mapreduce.Reducer<K1,V1,K2,V2>> reducerClass,
Class<K2> keyClass,
Class<V2> valueClass)
|
|
static
|
Mapred.reduce(PGroupedTable<K1,V1> input,
Class<? extends org.apache.hadoop.mapred.Reducer<K1,V1,K2,V2>> reducerClass,
Class<K2> keyClass,
Class<V2> valueClass)
|
|
static
|
Join.rightJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a right outer join on the specified PTable s. |
|
static
|
Sample.sample(PTable<K,V> input,
double probability)
A PTable<K, V> analogue of the sample function. |
|
static
|
Sample.sample(PTable<K,V> input,
Long seed,
double probability)
A PTable<K, V> analogue of the sample function, with the seed argument
exposed for testing purposes. |
|
static
|
Sort.sort(PTable<K,V> table)
Sorts the PTable using the natural ordering of its keys in ascending order. |
|
static
|
Sort.sort(PTable<K,V> table,
int numReducers,
Sort.Order key)
Sorts the PTable using the natural ordering of its keys in the
order specified with a client-specified number of reducers. |
|
static
|
Sort.sort(PTable<K,V> table,
Sort.Order key)
Sorts the PTable using the natural ordering of its keys with the given Order . |
|
static
|
SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
PTableType<U,V> ptype)
Perform a secondary sort on the given PTable instance and then apply a
DoFn to the resulting sorted data to yield an output PTable<U, V> . |
|
static
|
SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
PTableType<U,V> ptype,
int numReducers)
Perform a secondary sort on the given PTable instance and then apply a
DoFn to the resulting sorted data to yield an output PTable<U, V> , using
the given number of reducers. |
|
static
|
Aggregate.top(PTable<K,V> ptable,
int limit,
boolean maximize)
Selects the top N pairs from the given table, with sorting being performed on the values (i.e. |
Methods in org.apache.crunch.lib with parameters of type PTable | ||
---|---|---|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,?> first,
PTable<K,?>... rest)
Co-groups an arbitrary number of PTable arguments with a user-specified degree of parallelism
(a.k.a, number of reducers.) The largest table should come last in the ordering. |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,?> first,
PTable<K,?>... rest)
Co-groups an arbitrary number of PTable arguments with a user-specified degree of parallelism
(a.k.a, number of reducers.) The largest table should come last in the ordering. |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,U> left,
PTable<K,V> right)
Co-groups the two PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,U> left,
PTable<K,V> right)
Co-groups the two PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(int numReducers,
PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments with a user-specified degree of parallelism (a.k.a, number of
reducers.) |
|
static
|
Cogroup.cogroup(PTable<K,?> first,
PTable<K,?>... rest)
Co-groups an arbitrary number of PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,?> first,
PTable<K,?>... rest)
Co-groups an arbitrary number of PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,U> left,
PTable<K,V> right)
Co-groups the two PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,U> left,
PTable<K,V> right)
Co-groups the two PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third)
Co-groups the three PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments. |
|
static
|
Cogroup.cogroup(PTable<K,V1> first,
PTable<K,V2> second,
PTable<K,V3> third,
PTable<K,V4> fourth)
Co-groups the three PTable arguments. |
|
static
|
Aggregate.collectValues(PTable<K,V> collect)
|
|
static
|
Cartesian.cross(PTable<K1,U> left,
PTable<K2,V> right)
Performs a full cross join on the specified PTable s (using the same
strategy as Pig's CROSS operator). |
|
static
|
Cartesian.cross(PTable<K1,U> left,
PTable<K2,V> right)
Performs a full cross join on the specified PTable s (using the same
strategy as Pig's CROSS operator). |
|
static
|
Cartesian.cross(PTable<K1,U> left,
PTable<K2,V> right,
int parallelism)
Performs a full cross join on the specified PTable s (using the same
strategy as Pig's CROSS operator). |
|
static
|
Cartesian.cross(PTable<K1,U> left,
PTable<K2,V> right,
int parallelism)
Performs a full cross join on the specified PTable s (using the same
strategy as Pig's CROSS operator). |
|
static
|
Distinct.distinct(PTable<K,V> input)
A PTable<K, V> analogue of the distinct function. |
|
static
|
Distinct.distinct(PTable<K,V> input,
int flushEvery)
A PTable<K, V> analogue of the distinct function. |
|
static
|
Join.fullJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a full outer join on the specified PTable s. |
|
static
|
Join.fullJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a full outer join on the specified PTable s. |
|
static
|
Sample.groupedWeightedReservoirSample(PTable<Integer,Pair<T,N>> input,
int[] sampleSizes)
The most general purpose of the weighted reservoir sampling patterns that allows us to choose a random sample of elements for each of N input groups. |
|
static
|
Sample.groupedWeightedReservoirSample(PTable<Integer,Pair<T,N>> input,
int[] sampleSizes,
Long seed)
Same as the other groupedWeightedReservoirSample method, but include a seed for testing purposes. |
|
static
|
Join.innerJoin(PTable<K,U> left,
PTable<K,V> right)
Performs an inner join on the specified PTable s. |
|
static
|
Join.innerJoin(PTable<K,U> left,
PTable<K,V> right)
Performs an inner join on the specified PTable s. |
|
static
|
Join.join(PTable<K,U> left,
PTable<K,V> right)
Performs an inner join on the specified PTable s. |
|
static
|
Join.join(PTable<K,U> left,
PTable<K,V> right)
Performs an inner join on the specified PTable s. |
|
static
|
PTables.keys(PTable<K,V> ptable)
Extract the keys from the given PTable<K, V> as a PCollection<K> . |
|
static
|
Join.leftJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a left outer join on the specified PTable s. |
|
static
|
Join.leftJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a left outer join on the specified PTable s. |
|
static
|
Mapreduce.map(PTable<K1,V1> input,
Class<? extends org.apache.hadoop.mapreduce.Mapper<K1,V1,K2,V2>> mapperClass,
Class<K2> keyClass,
Class<V2> valueClass)
|
|
static
|
Mapred.map(PTable<K1,V1> input,
Class<? extends org.apache.hadoop.mapred.Mapper<K1,V1,K2,V2>> mapperClass,
Class<K2> keyClass,
Class<V2> valueClass)
|
|
static
|
PTables.mapKeys(PTable<K1,V> ptable,
MapFn<K1,K2> mapFn,
PType<K2> ptype)
Maps a PTable<K1, V> to a PTable<K2, V> using the given MapFn<K1, K2> on
the keys of the PTable . |
|
static
|
PTables.mapKeys(String name,
PTable<K1,V> ptable,
MapFn<K1,K2> mapFn,
PType<K2> ptype)
Maps a PTable<K1, V> to a PTable<K2, V> using the given MapFn<K1, K2> on
the keys of the PTable . |
|
static
|
PTables.mapValues(PTable<K,U> ptable,
MapFn<U,V> mapFn,
PType<V> ptype)
Maps a PTable<K, U> to a PTable<K, V> using the given MapFn<U, V> on
the values of the PTable . |
|
static
|
PTables.mapValues(String name,
PTable<K,U> ptable,
MapFn<U,V> mapFn,
PType<V> ptype)
Maps a PTable<K, U> to a PTable<K, V> using the given MapFn<U, V> on
the values of the PTable . |
|
static
|
Join.rightJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a right outer join on the specified PTable s. |
|
static
|
Join.rightJoin(PTable<K,U> left,
PTable<K,V> right)
Performs a right outer join on the specified PTable s. |
|
static
|
Sample.sample(PTable<K,V> input,
double probability)
A PTable<K, V> analogue of the sample function. |
|
static
|
Sample.sample(PTable<K,V> input,
Long seed,
double probability)
A PTable<K, V> analogue of the sample function, with the seed argument
exposed for testing purposes. |
|
static
|
Sort.sort(PTable<K,V> table)
Sorts the PTable using the natural ordering of its keys in ascending order. |
|
static
|
Sort.sort(PTable<K,V> table,
int numReducers,
Sort.Order key)
Sorts the PTable using the natural ordering of its keys in the
order specified with a client-specified number of reducers. |
|
static
|
Sort.sort(PTable<K,V> table,
Sort.Order key)
Sorts the PTable using the natural ordering of its keys with the given Order . |
|
static
|
SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
PTableType<U,V> ptype)
Perform a secondary sort on the given PTable instance and then apply a
DoFn to the resulting sorted data to yield an output PTable<U, V> . |
|
static
|
SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
DoFn<Pair<K,Iterable<Pair<V1,V2>>>,Pair<U,V>> doFn,
PTableType<U,V> ptype,
int numReducers)
Perform a secondary sort on the given PTable instance and then apply a
DoFn to the resulting sorted data to yield an output PTable<U, V> , using
the given number of reducers. |
|
static
|
SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
DoFn<Pair<K,Iterable<Pair<V1,V2>>>,T> doFn,
PType<T> ptype)
Perform a secondary sort on the given PTable instance and then apply a
DoFn to the resulting sorted data to yield an output PCollection<T> . |
|
static
|
SecondarySort.sortAndApply(PTable<K,Pair<V1,V2>> input,
DoFn<Pair<K,Iterable<Pair<V1,V2>>>,T> doFn,
PType<T> ptype,
int numReducers)
Perform a secondary sort on the given PTable instance and then apply a
DoFn to the resulting sorted data to yield an output PCollection<T> , using
the given number of reducers. |
|
static
|
Aggregate.top(PTable<K,V> ptable,
int limit,
boolean maximize)
Selects the top N pairs from the given table, with sorting being performed on the values (i.e. |
|
static
|
PTables.values(PTable<K,V> ptable)
Extract the values from the given PTable<K, V> as a PCollection<V> . |
Uses of PTable in org.apache.crunch.lib.join |
---|
Methods in org.apache.crunch.lib.join that return PTable | |
---|---|
PTable<K,Pair<U,V>> |
DefaultJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinFn<K,U,V> joinFn)
Perform a default join on the given PTable instances using a user-specified JoinFn . |
PTable<K,Pair<U,V>> |
ShardedJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
PTable<K,Pair<U,V>> |
MapsideJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
PTable<K,Pair<U,V>> |
JoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
Join two tables with the given join type. |
PTable<K,Pair<U,V>> |
DefaultJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
PTable<K,Pair<U,V>> |
BloomFilterJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
Methods in org.apache.crunch.lib.join with parameters of type PTable | ||
---|---|---|
PTable<K,Pair<U,V>> |
DefaultJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinFn<K,U,V> joinFn)
Perform a default join on the given PTable instances using a user-specified JoinFn . |
|
PTable<K,Pair<U,V>> |
DefaultJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinFn<K,U,V> joinFn)
Perform a default join on the given PTable instances using a user-specified JoinFn . |
|
PTable<K,Pair<U,V>> |
ShardedJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
PTable<K,Pair<U,V>> |
ShardedJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
PTable<K,Pair<U,V>> |
MapsideJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
PTable<K,Pair<U,V>> |
MapsideJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
PTable<K,Pair<U,V>> |
JoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
Join two tables with the given join type. |
|
PTable<K,Pair<U,V>> |
JoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
Join two tables with the given join type. |
|
PTable<K,Pair<U,V>> |
DefaultJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
PTable<K,Pair<U,V>> |
DefaultJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
PTable<K,Pair<U,V>> |
BloomFilterJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
PTable<K,Pair<U,V>> |
BloomFilterJoinStrategy.join(PTable<K,U> left,
PTable<K,V> right,
JoinType joinType)
|
|
static
|
OneToManyJoin.oneToManyJoin(PTable<K,U> left,
PTable<K,V> right,
DoFn<Pair<U,Iterable<V>>,T> postProcessFn,
PType<T> ptype)
Performs a join on two tables, where the left table only contains a single value per key. |
|
static
|
OneToManyJoin.oneToManyJoin(PTable<K,U> left,
PTable<K,V> right,
DoFn<Pair<U,Iterable<V>>,T> postProcessFn,
PType<T> ptype)
Performs a join on two tables, where the left table only contains a single value per key. |
|
static
|
OneToManyJoin.oneToManyJoin(PTable<K,U> left,
PTable<K,V> right,
DoFn<Pair<U,Iterable<V>>,T> postProcessFn,
PType<T> ptype,
int numReducers)
Supports a user-specified number of reducers for the one-to-many join. |
|
static
|
OneToManyJoin.oneToManyJoin(PTable<K,U> left,
PTable<K,V> right,
DoFn<Pair<U,Iterable<V>>,T> postProcessFn,
PType<T> ptype,
int numReducers)
Supports a user-specified number of reducers for the one-to-many join. |
Uses of PTable in org.apache.crunch.util |
---|
Methods in org.apache.crunch.util that return PTable | ||
---|---|---|
|
CrunchTool.read(TableSource<K,V> tableSource)
|
|
|||||||||
PREV NEXT | FRAMES NO FRAMES |