|
|||||||||
| PREV NEXT | FRAMES NO FRAMES | ||||||||
| Package org.apache.crunch |
|---|
| Class org.apache.crunch.CombineFn extends DoFn<Pair<S,Iterable<T>>,Pair<S,T>> implements Serializable |
|---|
| Class org.apache.crunch.CrunchRuntimeException extends RuntimeException implements Serializable |
|---|
| Serialized Fields |
|---|
boolean logged
| Class org.apache.crunch.DoFn extends Object implements Serializable |
|---|
| Class org.apache.crunch.FilterFn extends DoFn<T,T> implements Serializable |
|---|
| Class org.apache.crunch.GroupingOptions extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> partitionerClass
Class<T> groupingComparatorClass
Class<T> sortComparatorClass
boolean requireSortedKeys
int numReducers
Map<K,V> extraConf
| Class org.apache.crunch.MapFn extends DoFn<S,T> implements Serializable |
|---|
| Class org.apache.crunch.Pair extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Object first
Object second
| Package org.apache.crunch.contrib.bloomfilter |
|---|
| Class org.apache.crunch.contrib.bloomfilter.BloomFilterFn extends DoFn<S,Pair<String,org.apache.hadoop.util.bloom.BloomFilter>> implements Serializable |
|---|
| Package org.apache.crunch.contrib.text |
|---|
| Class org.apache.crunch.contrib.text.AbstractCompositeExtractor extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
TokenizerFactory tokenizerFactory
int errors
boolean errorOnLast
List<E> extractors
| Class org.apache.crunch.contrib.text.AbstractSimpleExtractor extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
int errors
boolean errorOnLast
Object defaultValue
TokenizerFactory scannerFactory
| Class org.apache.crunch.contrib.text.TokenizerFactory extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
String delim
String skip
Locale locale
Set<E> indices
boolean keep
| Package org.apache.crunch.examples |
|---|
| Class org.apache.crunch.examples.AverageBytesByIP extends org.apache.hadoop.conf.Configured implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> calulateAverage
DoFn<S,T> extractResponseSize
| Class org.apache.crunch.examples.SecondarySortExample extends org.apache.hadoop.conf.Configured implements Serializable |
|---|
| Class org.apache.crunch.examples.SortExample extends CrunchTool implements Serializable |
|---|
| Class org.apache.crunch.examples.TotalBytesByIP extends org.apache.hadoop.conf.Configured implements Serializable |
|---|
| Serialized Fields |
|---|
DoFn<S,T> extractIPResponseSize
| Class org.apache.crunch.examples.WordAggregationHBase extends org.apache.hadoop.conf.Configured implements Serializable |
|---|
| Serialized Fields |
|---|
byte[] COLUMN_FAMILY_SOURCE
byte[] COLUMN_QUALIFIER_SOURCE_PLAY
byte[] COLUMN_QUALIFIER_SOURCE_QUOTE
byte[] COLUMN_FAMILY_TARGET
byte[] COLUMN_QUALIFIER_TARGET_TEXT
| Class org.apache.crunch.examples.WordCount extends org.apache.hadoop.conf.Configured implements Serializable |
|---|
| Package org.apache.crunch.fn |
|---|
| Class org.apache.crunch.fn.Aggregators.SimpleAggregator extends Object implements Serializable |
|---|
| Class org.apache.crunch.fn.CompositeMapFn extends MapFn<R,T> implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> first
MapFn<S,T> second
| Class org.apache.crunch.fn.ExtractKeyFn extends MapFn<V,Pair<K,V>> implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> mapFn
| Class org.apache.crunch.fn.IdentityFn extends MapFn<T,T> implements Serializable |
|---|
| Class org.apache.crunch.fn.PairMapFn extends MapFn<Pair<K,V>,Pair<S,T>> implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> keys
MapFn<S,T> values
| Package org.apache.crunch.impl.mr.run |
|---|
| Class org.apache.crunch.impl.mr.run.RTNode extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
String nodeName
DoFn<S,T> fn
PType<T> outputPType
List<E> children
Converter<K,V,S,T> inputConverter
Converter<K,V,S,T> outputConverter
String outputName
| Package org.apache.crunch.impl.spark |
|---|
| Class org.apache.crunch.impl.spark.ByteArray extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
byte[] value
| Class org.apache.crunch.impl.spark.CounterAccumulatorParam extends Object implements Serializable |
|---|
| Class org.apache.crunch.impl.spark.IntByteArray extends ByteArray implements Serializable |
|---|
| Serialized Fields |
|---|
int partition
| Class org.apache.crunch.impl.spark.SparkComparator extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> cmpClass
GroupingOptions options
PGroupedTableType<K,V> ptype
SparkRuntimeContext ctxt
| Class org.apache.crunch.impl.spark.SparkPartitioner extends org.apache.spark.Partitioner implements Serializable |
|---|
| Serialized Fields |
|---|
int numPartitions
| Class org.apache.crunch.impl.spark.SparkRuntimeContext extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
org.apache.spark.broadcast.Broadcast<T> broadConf
org.apache.spark.Accumulator<T> counters
| Package org.apache.crunch.impl.spark.collect |
|---|
| Class org.apache.crunch.impl.spark.collect.ToByteArrayFunction extends org.apache.spark.api.java.function.PairFunction<scala.Tuple2<IntByteArray,List<byte[]>>,ByteArray,List<byte[]>> implements Serializable |
|---|
| Package org.apache.crunch.impl.spark.fn |
|---|
| Class org.apache.crunch.impl.spark.fn.CombineMapsideFunction extends org.apache.spark.api.java.function.PairFlatMapFunction<Iterator<scala.Tuple2<K,V>>,K,V> implements Serializable |
|---|
| Serialized Fields |
|---|
CombineFn<S,T> combineFn
SparkRuntimeContext ctxt
| Class org.apache.crunch.impl.spark.fn.FlatMapDoFn extends org.apache.spark.api.java.function.FlatMapFunction<Iterator<S>,T> implements Serializable |
|---|
| Serialized Fields |
|---|
DoFn<S,T> fn
SparkRuntimeContext ctxt
| Class org.apache.crunch.impl.spark.fn.FlatMapPairDoFn extends org.apache.spark.api.java.function.FlatMapFunction<Iterator<scala.Tuple2<K,V>>,T> implements Serializable |
|---|
| Serialized Fields |
|---|
DoFn<S,T> fn
SparkRuntimeContext ctxt
| Class org.apache.crunch.impl.spark.fn.InputConverterFunction extends org.apache.spark.api.java.function.Function<scala.Tuple2<K,V>,S> implements Serializable |
|---|
| Serialized Fields |
|---|
Converter<K,V,S,T> converter
| Class org.apache.crunch.impl.spark.fn.MapFunction extends org.apache.spark.api.java.function.Function<Object,Object> implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> fn
SparkRuntimeContext ctxt
boolean initialized
| Class org.apache.crunch.impl.spark.fn.MapOutputFunction extends org.apache.spark.api.java.function.PairFunction<Pair<K,V>,ByteArray,byte[]> implements Serializable |
|---|
| Serialized Fields |
|---|
SerDe<T> keySerde
SerDe<T> valueSerde
| Class org.apache.crunch.impl.spark.fn.OutputConverterFunction extends org.apache.spark.api.java.function.PairFunction<S,K,V> implements Serializable |
|---|
| Serialized Fields |
|---|
Converter<K,V,S,T> converter
| Class org.apache.crunch.impl.spark.fn.PairFlatMapDoFn extends org.apache.spark.api.java.function.PairFlatMapFunction<Iterator<T>,K,V> implements Serializable |
|---|
| Serialized Fields |
|---|
DoFn<S,T> fn
SparkRuntimeContext ctxt
| Class org.apache.crunch.impl.spark.fn.PairFlatMapPairDoFn extends org.apache.spark.api.java.function.PairFlatMapFunction<Iterator<scala.Tuple2<K,V>>,K2,V2> implements Serializable |
|---|
| Serialized Fields |
|---|
DoFn<S,T> fn
SparkRuntimeContext ctxt
| Class org.apache.crunch.impl.spark.fn.PairMapFunction extends org.apache.spark.api.java.function.Function<scala.Tuple2<K,V>,S> implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> fn
SparkRuntimeContext ctxt
boolean initialized
| Class org.apache.crunch.impl.spark.fn.PairMapIterableFunction extends org.apache.spark.api.java.function.PairFunction<Pair<K,List<V>>,S,Iterable<T>> implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> fn
SparkRuntimeContext runtimeContext
boolean initialized
| Class org.apache.crunch.impl.spark.fn.PartitionedMapOutputFunction extends org.apache.spark.api.java.function.PairFunction<Pair<K,V>,IntByteArray,byte[]> implements Serializable |
|---|
| Serialized Fields |
|---|
SerDe<T> keySerde
SerDe<T> valueSerde
PGroupedTableType<K,V> ptype
Class<T> partitionerClass
int numPartitions
SparkRuntimeContext runtimeContext
| Class org.apache.crunch.impl.spark.fn.ReduceGroupingFunction extends org.apache.spark.api.java.function.PairFlatMapFunction<Iterator<scala.Tuple2<ByteArray,List<byte[]>>>,ByteArray,List<byte[]>> implements Serializable |
|---|
| Serialized Fields |
|---|
GroupingOptions options
PGroupedTableType<K,V> ptype
SparkRuntimeContext ctxt
| Class org.apache.crunch.impl.spark.fn.ReduceInputFunction extends org.apache.spark.api.java.function.Function<scala.Tuple2<ByteArray,List<byte[]>>,Pair<K,List<V>>> implements Serializable |
|---|
| Serialized Fields |
|---|
SerDe<T> keySerDe
SerDe<T> valueSerDe
| Package org.apache.crunch.impl.spark.serde |
|---|
| Class org.apache.crunch.impl.spark.serde.AvroSerDe extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
AvroType<T> avroType
| Class org.apache.crunch.impl.spark.serde.WritableSerDe extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> clazz
| Package org.apache.crunch.io |
|---|
| Class org.apache.crunch.io.FormatBundle extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> formatClass
Map<K,V> extraConf
org.apache.hadoop.conf.Configuration conf
| Package org.apache.crunch.io.avro |
|---|
| Class org.apache.crunch.io.avro.AvroReadableData extends ReadableDataImpl<T> implements Serializable |
|---|
| Serialized Fields |
|---|
AvroType<T> avroType
| Package org.apache.crunch.io.avro.trevni |
|---|
| Class org.apache.crunch.io.avro.trevni.TrevniReadableData extends ReadableDataImpl<T> implements Serializable |
|---|
| Serialized Fields |
|---|
AvroType<T> avroType
| Package org.apache.crunch.io.hbase |
|---|
| Class org.apache.crunch.io.hbase.HBaseData extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
String table
String scanAsString
| Class org.apache.crunch.io.hbase.HBaseValueConverter extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> serializationClass
| Class org.apache.crunch.io.hbase.HFileReadableData extends ReadableDataImpl<org.apache.hadoop.hbase.KeyValue> implements Serializable |
|---|
| Package org.apache.crunch.io.impl |
|---|
| Class org.apache.crunch.io.impl.ReadableDataImpl extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
List<E> paths
| Package org.apache.crunch.io.parquet |
|---|
| Class org.apache.crunch.io.parquet.AvroParquetReadableData extends ReadableDataImpl<T> implements Serializable |
|---|
| Serialized Fields |
|---|
AvroType<T> avroType
| Package org.apache.crunch.io.seq |
|---|
| Class org.apache.crunch.io.seq.SeqFileReadableData extends ReadableDataImpl implements Serializable |
|---|
| Serialized Fields |
|---|
PType<T> ptype
| Package org.apache.crunch.io.text |
|---|
| Class org.apache.crunch.io.text.TextReadableData extends ReadableDataImpl<T> implements Serializable |
|---|
| Serialized Fields |
|---|
PType<T> ptype
String sep
| Package org.apache.crunch.lib |
|---|
| Class org.apache.crunch.lib.Aggregate.TopKCombineFn extends CombineFn<Integer,Pair<K,V>> implements Serializable |
|---|
| Serialized Fields |
|---|
int limit
boolean maximize
| Class org.apache.crunch.lib.Aggregate.TopKFn extends DoFn<Pair<K,V>,Pair<Integer,Pair<K,V>>> implements Serializable |
|---|
| Serialized Fields |
|---|
int limit
boolean maximize
| Package org.apache.crunch.lib.join |
|---|
| Class org.apache.crunch.lib.join.BloomFilterJoinStrategy extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
int vectorSize
int nbHash
JoinStrategy<K,U,V> delegateJoinStrategy
| Class org.apache.crunch.lib.join.DefaultJoinStrategy extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
int numReducers
| Class org.apache.crunch.lib.join.FullOuterJoinFn extends JoinFn<K,U,V> implements Serializable |
|---|
| Class org.apache.crunch.lib.join.InnerJoinFn extends JoinFn<K,U,V> implements Serializable |
|---|
| Class org.apache.crunch.lib.join.JoinFn extends DoFn<Pair<Pair<K,Integer>,Iterable<Pair<U,V>>>,Pair<K,Pair<U,V>>> implements Serializable |
|---|
| Serialized Fields |
|---|
PType<T> keyType
PType<T> leftValueType
| Class org.apache.crunch.lib.join.LeftOuterJoinFn extends JoinFn<K,U,V> implements Serializable |
|---|
| Class org.apache.crunch.lib.join.MapsideJoinStrategy extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
boolean materialize
| Class org.apache.crunch.lib.join.RightOuterJoinFn extends JoinFn<K,U,V> implements Serializable |
|---|
| Class org.apache.crunch.lib.join.ShardedJoinStrategy extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
JoinStrategy<K,U,V> wrappedJoinStrategy
ShardedJoinStrategy.ShardingStrategy<K> shardingStrategy
| Package org.apache.crunch.lib.sort |
|---|
| Class org.apache.crunch.lib.sort.SortFns.AvroGenericFn extends MapFn<V extends Tuple,org.apache.avro.generic.GenericRecord> implements Serializable |
|---|
| Serialized Fields |
|---|
int[] indices
String schemaJson
| Class org.apache.crunch.lib.sort.SortFns.SingleKeyFn extends MapFn<V extends Tuple,K> implements Serializable |
|---|
| Serialized Fields |
|---|
int index
| Class org.apache.crunch.lib.sort.SortFns.TupleKeyFn extends MapFn<V extends Tuple,K extends Tuple> implements Serializable |
|---|
| Serialized Fields |
|---|
int[] indices
TupleFactory<T extends Tuple> tupleFactory
| Package org.apache.crunch.types |
|---|
| Class org.apache.crunch.types.CollectionDeepCopier extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
PType<T> elementType
| Class org.apache.crunch.types.DeepCopier.NoOpDeepCopier extends Object implements Serializable |
|---|
| Class org.apache.crunch.types.MapDeepCopier extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
PType<T> ptype
| Class org.apache.crunch.types.PGroupedTableType extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
PTableType<K,V> tableType
| Class org.apache.crunch.types.PGroupedTableType.PairIterableMapFn extends MapFn<Pair<Object,Iterable<Object>>,Pair<K,Iterable<V>>> implements Serializable |
|---|
| Serialized Fields |
|---|
MapFn<S,T> keys
MapFn<S,T> values
| Class org.apache.crunch.types.TupleDeepCopier extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
TupleFactory<T extends Tuple> tupleFactory
List<E> elementTypes
| Class org.apache.crunch.types.TupleFactory extends Object implements Serializable |
|---|
| Package org.apache.crunch.types.avro |
|---|
| Class org.apache.crunch.types.avro.AvroDeepCopier.AvroGenericDeepCopier extends org.apache.crunch.types.avro.AvroDeepCopier<org.apache.avro.generic.GenericData.Record> implements Serializable |
|---|
| Class org.apache.crunch.types.avro.AvroDeepCopier.AvroReflectDeepCopier extends org.apache.crunch.types.avro.AvroDeepCopier<T> implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> valueClass
| Class org.apache.crunch.types.avro.AvroDeepCopier.AvroSpecificDeepCopier extends org.apache.crunch.types.avro.AvroDeepCopier<T> implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> valueClass
| Class org.apache.crunch.types.avro.AvroType extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> typeClass
String schemaString
MapFn<S,T> baseInputMapFn
MapFn<S,T> baseOutputMapFn
List<E> subTypes
DeepCopier<T> deepCopier
boolean initialized
| Package org.apache.crunch.types.writable |
|---|
| Class org.apache.crunch.types.writable.WritableDeepCopier extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> writableClass
| Class org.apache.crunch.types.writable.WritableType extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
Class<T> typeClass
Class<T> writableClass
Converter<K,V,S,T> converter
MapFn<S,T> inputFn
MapFn<S,T> outputFn
DeepCopier<T> deepCopier
List<E> subTypes
boolean initialized
| Package org.apache.crunch.util |
|---|
| Class org.apache.crunch.util.CrunchTool extends org.apache.hadoop.conf.Configured implements Serializable |
|---|
| Class org.apache.crunch.util.DelegatingReadableData extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
ReadableData<T> delegate
DoFn<S,T> fn
| Class org.apache.crunch.util.UnionReadableData extends Object implements Serializable |
|---|
| Serialized Fields |
|---|
List<E> data
|
|||||||||
| PREV NEXT | FRAMES NO FRAMES | ||||||||