Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



# Classes and Interfaces in #Cascading - 503 results found.
NameDescriptionTypePackageFramework
AggregateBy The first role is as a base class for composable aggregate operations that have a MapReduce Map side optimization for the Reduce side aggregation.Classcascading.pipe.assemblyCascading
AggregateByPropsClasscascading.pipe.assemblyCascading
AggregatorAn Aggregator takes the set of all values associated with a unique grouping and returns zero or more values.Interfacecascading.operationCascading
AggregatorCall This interface is generic, allowing the user to set a custom 'context' object when Aggregator.Interfacecascading.operationCascading
AggregatorEveryStageClasscascading.flow.stream.elementCascading
And Logically, if Filter.Classcascading.operation.filterCascading
AndElementExpressionClasscascading.flow.planner.iso.expressionCascading
AnnotatedDecoratedElementGraphClasscascading.flow.planner.graphCascading
AnnotatedGraphInterfacecascading.flow.planner.graphCascading
AnnotateGraphTransformerClasscascading.flow.planner.iso.transformerCascading
AnnotationExpressionClasscascading.flow.planner.iso.expressionCascading
ApplyAssertionLevelTransformerClasscascading.flow.planner.rule.transformerCascading
ApplyDebugLevelTransformerClasscascading.flow.planner.rule.transformerCascading
AppProps Flow may or may not be required to have set.Classcascading.propertyCascading
AssemblyPlanner This allows for new languages or frameworks that may require additional meta-data from the underlying platform or environment.Interfacecascading.flowCascading
AssertedClasscascading.flow.planner.iso.assertionCascading
AssertEquals to the number of argument values Tuple and each constructor value is .Classcascading.operation.assertionCascading
AssertEqualsAll provided on the constructor.Classcascading.operation.assertionCascading
AssertExpression returns true for the given expression pass the assertion.Classcascading.operation.assertionCascading
AssertGroupBaseClasscascading.operation.assertionCascading
AssertGroupSizeEquals is equal the given size.Classcascading.operation.assertionCascading
AssertGroupSizeLessThanClass AssertGroupSizeEquals is an GroupAssertion that asserts the number of items in the current group is less than the given size.Classcascading.operation.assertionCascading
AssertGroupSizeMoreThanClass AssertGroupSizeEquals is an GroupAssertion that asserts the number of items in the current group is more than the given size.Classcascading.operation.assertionCascading
AssertionInterfacecascading.operationCascading
AssertionExceptionClasscascading.operationCascading
AssertionLevelEnum AssertionLevel designates the level of a given Assertion instance.Classcascading.operationCascading
AssertMatches Tuple by joining each individual element of the Tuple with a tab character (\t) unless otherwise specified.Classcascading.operation.assertionCascading
AssertMatchesAll Tuple element individually.Classcascading.operation.assertionCascading
AssertNotEquals to the number of argument values Tuple and each constructor value is not .Classcascading.operation.assertionCascading
AssertNotNullClasscascading.operation.assertionCascading
AssertNullClasscascading.operation.assertionCascading
AssertSizeEquals On evaluation, Tuple.Classcascading.operation.assertionCascading
AssertSizeLessThan On evaluation, Tuple.Classcascading.operation.assertionCascading
AssertSizeMoreThan On evaluation, Tuple.Classcascading.operation.assertionCascading
AverageClasscascading.operation.aggregatorCascading
AverageBy Typically finding the average value in a tuple stream relies on a GroupBy and a Average Aggregator operation.Classcascading.pipe.assemblyCascading
BaseAnnotatedElementGraphClasscascading.flow.planner.graphCascading
BaseAssertion this class is not required, but does provide some convenience functions for signaling assertion failures.Classcascading.operation.assertionCascading
BaseCacheFactoryBase class for all CacheFactories for creating CascadingCache instances.Classcascading.util.cacheCascading
BaseCascadeClasscascading.cascadeCascading
BaseElementGraphClasscascading.flow.planner.graphCascading
BaseFlowClasscascading.flowCascading
BaseFlowNodeClasscascading.flow.plannerCascading
BaseFlowStepClass FlowStep is an internal representation of a given Job to be executed on a remote cluster.Classcascading.flow.plannerCascading
BaseJoinerClasscascading.pipe.joinerCascading
BaseOperation the Each or Every Pipe.Classcascading.operationCascading
BasePartitionTapClasscascading.tap.partitionCascading
BaseProcessGraphClasscascading.flow.planner.processCascading
BaseStateClasscascading.management.stateCascading
BigDecimalCoerceClasscascading.tuple.coerceCascading
BlockingHashJoinAnnotatorClasscascading.flow.planner.rule.annotatorCascading
BlockingModeClasscascading.flow.stream.annotationsCascading
BooleanCoerceClasscascading.tuple.coerceCascading
BooleanObjectCoerceClasscascading.tuple.coerceCascading
BoundariesElementExpressionClasscascading.flow.planner.rule.elementexpressionCascading
BoundaryThe Boundary class is only used internally by the planner to mark the boundaries between partitions within In MapReduce, Taps are used.Classcascading.pipeCascading
BoundaryElementFactoryClasscascading.flow.planner.rule.transformerCascading
BoundaryStageClasscascading.flow.stream.elementCascading
BoundedElementMultiGraphClasscascading.flow.planner.graphCascading
BufferA Buffer is similar to an Aggregator by the fact that it operates on unique groups of values.Interfacecascading.operationCascading
BufferAfterEveryAssertClasscascading.flow.planner.rule.assertionCascading
BufferAfterEveryExpressionClasscascading.flow.planner.rule.expressionCascading
BufferCallInterfacecascading.operationCascading
BufferEveryWindowClasscascading.flow.stream.elementCascading
BufferJoin will implement a custom join strategy.Classcascading.pipe.joinerCascading
CacheEvictionCallbackCacheEvictionCallBack is an interface to be used in conjunction with CascadingCache instances.Interfacecascading.util.cacheCascading
CascadeA Cascade is an assembly of Flow instances that share or depend on equivalent Tap instances and are executed as a single group.Interfacecascading.cascadeCascading
CascadeConnector Note order is not significant when adding passing Flow instances to the connect method.Classcascading.cascadeCascading
CascadeDef This allows for ad-hoc building of Cascade data and meta-data like tags.Classcascading.cascadeCascading
CascadeExceptionClasscascading.cascadeCascading
CascadeListener Any RuntimeException thrown from any of the listener methods will force the given cascade to stop by calling Cascade.Interfacecascading.cascadeCascading
CascadeProps through a CascadeConnector.Classcascading.cascadeCascading
Cascades instances via the CascadeConnector and FlowConnector, respectively.Classcascading.cascadeCascading
CascadeStatsClasscascading.statsCascading
CascadingCacheInterface that defines a Cache.Interfacecascading.util.cacheCascading
CascadingExceptionClasscascadingCascading
CascadingFactory Factory instances are created process side (in a cluster for example) to augment any of the internal strategies.Interfacecascading.providerCascading
CascadingServiceInterfacecascading.providerCascading
CascadingServices monitoring and management systems.Classcascading.managementCascading
CascadingStats core elements that have state.Classcascading.statsCascading
CascadingTestCase It included a few helpful utility methods for testing Cascading applications.ClasscascadingCascading
CharacterCoerceClasscascading.tuple.coerceCascading
CharacterObjectCoerceClasscascading.tuple.coerceCascading
CheckpointThe Checkpoint pipe, if supported by the current planner, will force data to be persisted at the point in the tuple stream an instance of Checkpoint is inserted into the pipe assembly.Classcascading.pipeCascading
ClientStateClasscascading.management.stateCascading
CloseableIteratorInterfacecascading.utilCascading
CloseReducingDuctClasscascading.flow.stream.ductCascading
Coerce If the given type is a primitive (long), and the tuple value is null, 0 is returned.Classcascading.pipe.assemblyCascading
CoercibleType It is the role of implementations of this interface to maintain a canonical representation of a given value and to allow for coercions between some type representation to the canonical type and back.Interfacecascading.tuple.typeCascading
CoercionsCoercions class is a helper class for managing primitive value coercions.Classcascading.tuple.coerceCascading
CoGroupThe CoGroup pipe allows for two or more tuple streams to join into a single stream via an optional Joiner.Classcascading.pipeCascading
ComparisonThe Comparison interface allows specific underlying type mechanisms to additionally return relevant Comparator implementations when required internally.Interfacecascading.tupleCascading
ComponentAttributeProviderInterfacecascading.util.jgraphtCascading
CompositeTap This information is required by the planner in order to properly configure the underlying platform.Interfacecascading.tapCascading
ConcreteCallClass OperationCall is the common base class for FunctionCall, FilterCall, AggregatorCall, ValueAssertionCall, and GroupAssertionCall.Classcascading.operationCascading
ConcreteCallThe concrete base class for SourceCall and SinkCall.Classcascading.schemeCascading
ConfigDefThe ConfigDef class allows for the creation of a configuration properties template to be applied to an existing properties configuration set.Classcascading.propertyCascading
ConsecutiveTapsExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
ContractedGraphTransformerClasscascading.flow.planner.iso.transformerCascading
ContractedTransformerClasscascading.flow.planner.iso.transformerCascading
Count Note the resulting value for count is always a long.Classcascading.operation.aggregatorCascading
CountBy values for the groupingFields fields.Classcascading.pipe.assemblyCascading
Counter Internally, the isRemove(cascading.Classcascading.operation.stateCascading
DateFormatter is the number of milliseconds since January 1, 1970, 00:00:00 GMT, using the SimpleDateFormat syntax.Classcascading.operation.textCascading
DateOperationClasscascading.operation.textCascading
DateParser since January 1, 1970, 00:00:00 GMT, using the SimpleDateFormat syntax.Classcascading.operation.textCascading
DateTypeClass DateCoercibleType is an implementation of CoercibleType.Classcascading.tuple.typeCascading
Debug Currently, if printFields is true, they will print every 10 Tuples.Classcascading.operationCascading
DebugLevelEnum DebugLevel designates the level of a given Debug instance.Classcascading.operationCascading
DecoratedElementGraphClasscascading.flow.planner.graphCascading
DecoratorTap It also provides an additional generic field that may hold any custom type, this allows implementations to attach any meta-info to the tap being decorated.Classcascading.tapCascading
DelimitedParser It maybe sub-classed to change its behavior.Classcascading.scheme.utilCascading
DelimitedPartitionDelimitedPartition is an implementation of the Partition interface that allows for simple text delimited paths as partitions.Classcascading.tap.partitionCascading
DirectMappedCacheDirectMappedCache is an implementation of the CascadingCache interface following the semantics of http://en.Classcascading.util.cacheCascading
DirectMappedCacheFactoryConcrete sub-class of BaseCacheFactory for creating DirectMappedCache instances.Classcascading.util.cacheCascading
Discard Use this pipe to narrow a stream of tuples, removing unused data.Classcascading.pipe.assemblyCascading
DocumentServiceInterfacecascading.managementCascading
DocumentServiceExceptionException DocumentServiceException is thrown from within a DocumentService instance.Classcascading.managementCascading
DOTExporterClasscascading.util.jgraphtCascading
DOTProcessGraphWriterThis class is a derivative of the JGraphT DOTExporter, with numerous enhancements but with retained compatibility.Classcascading.utilCascading
DoubleCoerceClasscascading.tuple.coerceCascading
DoubleObjectCoerceClasscascading.tuple.coerceCascading
DualStreamedAccumulatedExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
DuctClasscascading.flow.stream.ductCascading
DuctExceptionClasscascading.flow.stream.ductCascading
DuctGraphClasscascading.flow.stream.ductCascading
EachThe Each operator applies either a Function or a Filter to each entry in the Tuple stream.Classcascading.pipeCascading
EachStageClasscascading.flow.stream.elementCascading
ElementAnnotationClasscascading.flow.planner.isoCascading
ElementCaptureClasscascading.flow.planner.iso.expressionCascading
ElementDirectedGraphClasscascading.flow.planner.graphCascading
ElementDuctInterfacecascading.flow.stream.elementCascading
ElementExpressionClasscascading.flow.planner.iso.expressionCascading
ElementFactoryInterfacecascading.flow.planner.iso.transformerCascading
ElementFlowProcessClasscascading.flow.stream.elementCascading
ElementGraph An element graph represents an assembly of Pipe instances bound to source and sink Typically an element graph is fed to a FlowPlanner which in return createsInterfacecascading.flow.planner.graphCascading
ElementGraphException the Cascading internal "graph" representation.Classcascading.flow.plannerCascading
ElementGraphsClasscascading.flow.planner.graphCascading
ElementMaskSubGraphClasscascading.flow.planner.graphCascading
ElementMultiGraphClasscascading.flow.planner.graphCascading
ElementStageClasscascading.flow.stream.elementCascading
ElementSubGraphClasscascading.flow.planner.graphCascading
EnumMultiMapClasscascading.utilCascading
EveryThe Every operator applies an Aggregator or Buffer to every grouping.Classcascading.pipeCascading
EveryAfterBufferAssertClasscascading.flow.planner.rule.assertionCascading
EveryAfterBufferExpressionClasscascading.flow.planner.rule.expressionCascading
EveryStageClasscascading.flow.stream.elementCascading
ExecActionClasscascading.flow.planner.ruleCascading
ExpressionInterfacecascading.flow.planner.iso.expressionCascading
ExpressionFilter returns true for the given expression will be removed from the stream.Classcascading.operation.expressionCascading
ExpressionFunction is based on the Janino compiler.Classcascading.operation.expressionCascading
ExpressionGraphClasscascading.flow.planner.iso.expressionCascading
ExpressionGraphPartitionerClasscascading.flow.planner.iso.subgraph.partitionerCascading
ExpressionOperationClasscascading.operation.expressionCascading
ExpressionRulePartitioner sub-graphs as partitions.Classcascading.flow.planner.rule.partitionerCascading
ExpressionSubGraphIteratorClasscascading.flow.planner.iso.subgraph.iteratorCascading
ExtentEnum Extent provides simple markers for the head and tail of an ElementGraph FlowElement graph.Classcascading.flow.planner.graphCascading
ExtentBaseClasscascading.operation.aggregatorCascading
ExtremaValueBase Comparable types and the Comparable.Classcascading.operation.aggregatorCascading
FactoryLoader CascadingFactory instances used by internal frameworks.Classcascading.providerCascading
FieldFormatter This function uses the Formatter class for formatting the argument tuple values into a new string.Classcascading.operation.textCascading
FieldJoinerClasscascading.operation.textCascading
Fields name, or it may be a literal Integer value representing a position, where positions start at position 0.Classcascading.tupleCascading
FieldsResolverException select from the sourceFields.Classcascading.tupleCascading
FieldTypeResolverInterfacecascading.scheme.utilCascading
FileTypeInterfacecascading.tap.typeCascading
Filter A Filter is responsible for testing a Tuple to see if it should be removed from the tuple stream.Interfacecascading.operationCascading
FilterCallInterfacecascading.operationCascading
FilterEachStageClasscascading.flow.stream.elementCascading
FilterNotNull is a null value.Classcascading.operation.filterCascading
FilterNull is not a null value.Classcascading.operation.filterCascading
First By default, it returns the first Tuple of Fields.Classcascading.operation.aggregatorCascading
FirstBy Typically finding the first Tuple in a tuple stream grouping relies on a GroupBy and a First Aggregator operation.Classcascading.pipe.assemblyCascading
FirstNBuffer are returned the Buffer stops iterating the arguments unlike the First Aggregator which by contract sees all the values in the grouping.Classcascading.operation.bufferCascading
FloatCoerceClasscascading.tuple.coerceCascading
FloatObjectCoerceClasscascading.tuple.coerceCascading
FlowA Flow is a logical unit of work declared by an assembly of Pipe instances connected to source and sink Tap instances.Interfacecascading.flowCascading
FlowConnector See the FlowDef class for a fluent way to define a new Flow.Classcascading.flowCascading
FlowConnectorPropsThe class FlowConnectorProps is a fluent helper class for setting FlowConnector specific properties through the FlowConnector constructor.Classcascading.flowCascading
FlowDef This allows for ad-hoc building of Flow data and meta-data, like tags.Classcascading.flowCascading
FlowDescriptorsConstants to be used as key in Flow#getFlowDescriptor.Interfacecascading.flowCascading
FlowElement for users to interact with these methods directly.Interfacecascading.flowCascading
FlowElementExpressionClasscascading.flow.planner.iso.expressionCascading
FlowElementGraphClass ElementGraph represents the executable FlowElement graph.Classcascading.flow.planner.graphCascading
FlowElementsClasscascading.flowCascading
FlowExceptionFlowException instances are thrown on errors when executing a Flow.Classcascading.flowCascading
FlowGraphClasscascading.cascade.plannerCascading
FlowListener Any RuntimeException thrown from any of the listener methods will force the given flow to stop by calling Flow.Interfacecascading.flowCascading
FlowNode FlowStep and may have many siblings within the FlowStep.Interfacecascading.flowCascading
FlowNodeGraphClasscascading.flow.planner.processCascading
FlowNodeStatsClasscascading.statsCascading
FlowPlanner This planner support tracing execution of each rule.Classcascading.flow.plannerCascading
FlowProcessFlowProcess implementations provide a call-back interface into the current computing system.Classcascading.flowCascading
FlowProcessWrapperClasscascading.flowCascading
FlowPropsClasscascading.flowCascading
FlowRuntimeProps These properties apply to the cluster or remote side of the Flow execution.Classcascading.flowCascading
FlowsFlows is a utility helper class.Classcascading.flowCascading
FlowSessionFlowSession implementations provide a call-back interface into the current flow management system, if any.Classcascading.flowCascading
FlowSkipIfSinkExists true if the Flow sink exists, regardless if it is stale or not.Classcascading.flowCascading
FlowSkipIfSinkNotStale true if the Flow sink exists and is not stale in relation to the Flow sources.Classcascading.flowCascading
FlowSkipStrategy be skipped when executed in a Cascade.Interfacecascading.flowCascading
FlowSliceStatsTypically CascadingStats objects have an internal state model with timings, the FlowSliceStats is a simplified Stats object and only reports what the underlying platform reports, not the client side observations.Classcascading.statsCascading
FlowStatsClasscascading.statsCascading
FlowStep planning, pipe assemblies are broken down into "steps" and encapsulated in this class.Interfacecascading.flowCascading
FlowStepGraphClasscascading.flow.planner.processCascading
FlowStepJobClasscascading.flow.plannerCascading
FlowStepListenerInterfacecascading.flowCascading
FlowStepStatsClasscascading.statsCascading
FlowStepStrategyThe FlowStepStrategy interface allows for on the fly customization of FlowStep configuration values before they are submitted to the underlying platform.Interfacecascading.flowCascading
ForeverValueIteratorThe ForeverValueIterator class will iterate over a single value forever.Classcascading.utilCascading
ForkClasscascading.flow.stream.ductCascading
Function A Function is responsible for taking Tuple arguments and returning one or more result Tuples.Interfacecascading.operationCascading
FunctionCallInterfacecascading.operationCascading
FunctionEachStageClasscascading.flow.stream.elementCascading
GateClasscascading.flow.stream.ductCascading
GraphAssertClasscascading.flow.planner.iso.assertionCascading
GraphFinderClasscascading.flow.planner.iso.finderCascading
GraphFinderExceptionClasscascading.flow.planner.iso.finderCascading
GraphPartitionerClasscascading.flow.planner.iso.subgraphCascading
GraphResultClasscascading.flow.planner.isoCascading
GraphTransformerClasscascading.flow.planner.iso.transformerCascading
GroupInterfacecascading.pipeCascading
GroupAssertion Implementers should also extend BaseOperation.Interfacecascading.operationCascading
GroupAssertionCall This interface is generic, allowing the user to set a custom 'context' object when GroupAssertion.Interfacecascading.operationCascading
GroupAssertionEveryStageClasscascading.flow.stream.elementCascading
GroupByThe GroupBy pipe groups the Tuple stream by the given groupFields.Classcascading.pipeCascading
GroupingClasscascading.flow.stream.ductCascading
GroupingSpliceGateClasscascading.flow.stream.elementCascading
GroupOrMergeElementExpressionClasscascading.flow.planner.rule.elementexpressionCascading
GroupTapExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
HasherThe Hasher allows a Comparator implementation to also be delegated to during hashCode generation during grouping partitioning.Interfacecascading.tupleCascading
HashJoinThe HashJoin pipe allows for two or more tuple streams to join into a single stream via a Joiner when all but one tuple stream is considered small enough to fit into memory.Classcascading.pipeCascading
HashJoinBlockingHashJoinAnnotatorClasscascading.flow.planner.rule.annotatorCascading
IdentifierGraphClasscascading.cascade.plannerCascading
IdentityThe Identity function simply passes incoming arguments back out again.Classcascading.operationCascading
IgnoreAnnotationsHashSetClasscascading.flow.planner.graphCascading
IgnoresAnnotationsElementGraphClasscascading.flow.planner.graphCascading
IncludeRemainderSubGraphIteratorClasscascading.flow.planner.iso.subgraph.iteratorCascading
IndexTupleClasscascading.tuple.ioCascading
InnerJoin and inner join of the CoGrouper internal grouped tuple collections.Classcascading.pipe.joinerCascading
InsertClasscascading.operationCascading
InsertionGraphTransformerClasscascading.flow.planner.iso.transformerCascading
IntegerCoerceClasscascading.tuple.coerceCascading
IntegerNameProviderClasscascading.util.jgraphtCascading
IntegerObjectCoerceClasscascading.tuple.coerceCascading
IntermediateTapElementFactoryClasscascading.flow.planner.rule.transformerCascading
IORoleEnum IORole specifies how a FlowElement will be used during streaming.Classcascading.flow.stream.graphCascading
Joiner Joins perform based on the equality of the join keys.Interfacecascading.pipe.joinerCascading
JoinerClosure This class is provided to a Joiner.Classcascading.pipe.joinerCascading
Last By default, it returns the last Tuple of Fields.Classcascading.operation.aggregatorCascading
LeftJoin a left inner, right outer join of the CoGrouper internal grouped tuple collections.Classcascading.pipe.joinerCascading
Limit Note that the limit value is roughly a suggestion.Classcascading.operation.filterCascading
LogicClasscascading.operation.filterCascading
LogUtilClasscascading.utilCascading
LoneGroupAssertVerifies that there are not only GroupAssertions following any given Group instance.Classcascading.flow.planner.rule.assertionCascading
LoneGroupExpressionClasscascading.flow.planner.rule.expressionCascading
LongCoerceClasscascading.tuple.coerceCascading
LongObjectCoerceClasscascading.tuple.coerceCascading
LRUHashMapCache evict the least recently used key.Classcascading.util.cacheCascading
LRUHashMapCacheFactoryClasscascading.util.cacheCascading
MatchClasscascading.flow.planner.iso.finderCascading
MaxBy Typically finding the max value of a field in a tuple stream relies on a GroupBy and a MaxValue Aggregator operation.Classcascading.pipe.assemblyCascading
MaxValue Values are expected to be Comparable types vs numeric representations and the Comparable.Classcascading.operation.aggregatorCascading
MemoryCoGroupClosureClasscascading.flow.stream.elementCascading
MemoryCoGroupGateClasscascading.flow.stream.elementCascading
MemoryHashJoinGateClasscascading.flow.stream.elementCascading
MemorySpliceGateClasscascading.flow.stream.elementCascading
MergeThe Merge Pipe allows for multiple branches, with the same fields to be spliced back into a single stream.Classcascading.pipeCascading
MergeStageClasscascading.flow.stream.elementCascading
MetricsServiceInterfacecascading.managementCascading
MinBy Typically finding the min value of a field in a tuple stream relies on a GroupBy and a MinValue Aggregator operation.Classcascading.pipe.assemblyCascading
MinValueClass Min is an Aggregator that returns the minimum value encountered in the current group.Classcascading.operation.aggregatorCascading
MissingGroupAssertClasscascading.flow.planner.rule.assertionCascading
MissingGroupExpressionClasscascading.flow.planner.rule.expressionCascading
MixedJoin Joiner and return tuples that represent a join as defined by the given boolean array.Classcascading.pipe.joinerCascading
MultiMapClasscascading.utilCascading
MultiSinkTap multiple child Tap instances simultaneously.Classcascading.tapCascading
MultiSourceTap multiple files to be concatenated into the requesting pipe assembly, if they all share the same Scheme instance.Classcascading.tapCascading
MultiTapGroupExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
Murmur3Murmur3 is a fast non cryptographic hash algorithm.Classcascading.utilCascading
MutateGraphTransformerClasscascading.flow.planner.iso.transformerCascading
NoCoGroupJoinTapExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NodeStreamGraphClasscascading.flow.stream.graphCascading
NoGroupJoinMergeBoundaryTapExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NoGroupJoinTapExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NoGroupTapExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NoMergeTapExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NonBlockedBlockedJoinAnnotatorExpressionClasscascading.flow.planner.rule.expressionCascading
NonBlockedBlockedJoinExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NonBlockedBlockedJoinJoinAnnotatorExpressionClasscascading.flow.planner.rule.expressionCascading
NonBlockedBlockedJoinJoinExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NonSafeAndSplitAndSyncPipeExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
NonSafeOperationExpressionClasscascading.flow.planner.iso.expressionCascading
NoOp Use with Fields.Classcascading.operationCascading
NoOpPipeExpressionClasscascading.flow.planner.rule.expressionCascading
NoOpPipeExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
Not Logically, if Filter.Classcascading.operation.filterCascading
NotElementExpressionClasscascading.flow.planner.iso.expressionCascading
NullNotEquivalentComparator the result of lhs.Classcascading.utilCascading
NullScheme It is typically used as a placeholder where a Scheme instance is needed but generally ignored.Classcascading.schemeCascading
ObjectCoerceClasscascading.tuple.coerceCascading
OnlyPipeExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
OpenDuctClasscascading.flow.stream.ductCascading
OpenReducingDuctClasscascading.flow.stream.ductCascading
Operation Specifically Function, Filter, Aggregator, Buffer, and Assertion.Interfacecascading.operationCascading
OperationCallInterfacecascading.operationCascading
OperationExceptionClasscascading.operationCascading
OperationExpressionClasscascading.flow.planner.iso.expressionCascading
OperatorAn Operator is a type of Pipe.Classcascading.pipeCascading
OperatorExceptionClasscascading.pipeCascading
OperatorStageClasscascading.flow.stream.elementCascading
Or Logically, if Filter.Classcascading.operation.filterCascading
OrderOrder describes the order in which Property annotations shall be displayed.Classcascading.management.annotationCascading
OrderedHashMapCache is used by default by Unique and AggregateBy and theirDirectMappedCacheFactory, Classcascading.util.cacheCascading
OrderedHashMapCacheFactoryClasscascading.util.cacheCascading
OrdinalScopeExpressionClasscascading.flow.planner.iso.expressionCascading
OrElementExpressionClasscascading.flow.planner.iso.expressionCascading
OuterJoin and outer join of the CoGrouper internal grouped tuple collections.Classcascading.pipe.joinerCascading
PairClasscascading.utilCascading
PartitionThe Partition interface allows for custom partitioning mechanisms to be created with the BasePartitionTap A partition is a directory on a filesystem, where the directory contains data related to the files underneathInterfacecascading.tap.partitionCascading
PartitionsClasscascading.flow.planner.iso.subgraphCascading
PartitionTapPropsClasscascading.tap.partitionCascading
PartitionTupleEntryIteratorClasscascading.tap.partitionCascading
PathScopeExpressionClasscascading.flow.planner.iso.expressionCascading
Pipe processing model types, specifically Each, Every, GroupBy, CoGroup, Merge, HashJoin, and SubAssembly.Classcascading.pipeCascading
PlannedOperation that use a PlannerLevel value to inform the FlowPlanner how to treat the operation during job planning.Interfacecascading.operationCascading
PlannerContextClasscascading.flow.plannerCascading
PlannerException For debugging purposes, the PlannerException holds a copy of the internal job representation which can be written out to disk and visualized with tools that support theClasscascading.flow.plannerCascading
PlannerInfoClasscascading.flow.plannerCascading
PlannerLevel It should be noted that all enum implementations of this interface must declare a NONE or equivalent instance.Interfacecascading.operationCascading
PlannerLevelElementExpressionClasscascading.flow.planner.iso.expressionCascading
PlannerLevelExpressionClasscascading.flow.planner.rule.expressionCascading
PlannerLevelPipeExpressionGraphClasscascading.flow.planner.iso.expressionCascading
PlanPhaseClasscascading.flow.planner.ruleCascading
PlatformInfoClasscascading.flow.plannerCascading
ProcessEdgeClasscascading.flow.planner.processCascading
ProcessFlow Use this class to allow custom Riffle jobs to participate in the Cascade scheduler.Classcascading.flow.processCascading
ProcessFlowStatsProcessFlowStats is a sub-class of FlowStats which can fetch counters from a ProcessWrapper and hook them into the stats mechanism of Cascading.Classcascading.stats.processCascading
ProcessFlowStepClasscascading.flow.processCascading
ProcessGraphInterfacecascading.flow.planner.processCascading
ProcessGraphsClasscascading.flow.planner.processCascading
ProcessLevelClasscascading.flow.planner.ruleCascading
ProcessLoggerInterfacecascading.utilCascading
ProcessModelInterfacecascading.flow.planner.processCascading
ProcessModelsClasscascading.flow.planner.processCascading
ProcessStepStatsProcessStepStats is an implementation of FlowStepStats used in non-hadoop based flows like ProcessFlow.Classcascading.stats.processCascading
PropertyProperty annotations can be used to send additional information about certain aspects of Cascading classes to the DocumentService.Classcascading.management.annotationCascading
PropertyConfiguredPropertyConfigured is an annotation to document the configuration key and the default value of a given @Property annotation on the same AnnotatedElement.Classcascading.management.annotationCascading
PropertyDescriptionPropertyDescription is an annotation that can be used to describe the @Property annotation present on the same AnnotatedElement.Classcascading.management.annotationCascading
PropertyOrderPropertyOrder is an annotation at the class level that controls the sort order of the Property annotations present Order.Classcascading.management.annotationCascading
PropertyRegexSanitizerPropertyRegexSanitizer is an annotation to be used in conjunction with a Property annotation to sanitize values containing sensitive information with a given regular expression.Classcascading.management.annotationCascading
PropertySanitizerPropertySanitizer is an annotation to be used in conjunction with a Property annotation to sanitize values containing sensitive information.Classcascading.management.annotationCascading
PropertyUtilClasscascading.propertyCascading
Props Use the sub-classes to either create a Properties instance with custom or default values to be passed to any sub-system that requires a Map or Properties instance of properties and values.Classcascading.propertyCascading
ProviderLoader This loader can optinally load a provider implementation within its own ClassLoader using the ChildFirstURLClassLoader.Classcascading.providerCascading
ProvidesCountersInterfacecascading.statsCascading
RecursiveGraphTransformerClasscascading.flow.planner.iso.transformerCascading
ReducingInterfacecascading.flow.stream.ductCascading
RegexFilter the Tuple stream accordingly.Classcascading.operation.regexCascading
RegexGenerator Note a null valued argument passed to the parser will be converted to an empty string ("") before the regex is applied.Classcascading.operation.regexCascading
RegexMatcher This operation uses Matcher internally, specifically the method Matcher.Classcascading.operation.regexCascading
RegexOperationClasscascading.operation.regexCascading
RegexParser RegexParser only expects one field value.Classcascading.operation.regexCascading
RegexReplace RegexReplace only expects one field value.Classcascading.operation.regexCascading
RegexSplitGeneratorClass RegexGenerator will emit a new Tuple for every split on the incoming argument value delimited by the given patternString.Classcascading.operation.regexCascading
RegexSplitter RegexSplitter only expects one field value.Classcascading.operation.regexCascading
RemoveBranchGraphTransformerClasscascading.flow.planner.iso.transformerCascading
RemoveNoOpPipeTransformerClasscascading.flow.planner.rule.transformerCascading
Rename Note that if any input field names are not given, they will retain their names.Classcascading.pipe.assemblyCascading
ReplaceGraphTransformerClasscascading.flow.planner.iso.transformerCascading
ResultTreeClasscascading.flow.planner.rule.utilCascading
Retain Use this pipe to narrow a stream of tuples, removing unused data.Classcascading.pipe.assemblyCascading
RightJoin a left outer, right inner join of the CoGrouper internal grouped tuple collections.Classcascading.pipe.joinerCascading
RuleInterfacecascading.flow.planner.ruleCascading
RuleAnnotationTransformerClasscascading.flow.planner.rule.transformerCascading
RuleAssertThe RuleAssert class is responsible for asserting the structure of a element graph.Classcascading.flow.planner.ruleCascading
RuleContractedTransformerClasscascading.flow.planner.rule.transformerCascading
RuleExecClasscascading.flow.planner.ruleCascading
RuleExpressionA RuleExpression describes where a Rule is applied in an element graph.Classcascading.flow.planner.ruleCascading
RuleInsertionTransformerClasscascading.flow.planner.rule.transformerCascading
RuleModeClasscascading.flow.planner.ruleCascading
RulePartitionerThe RulePartitioner class is responsible for partitioning an element graph into smaller sub-graphs.Classcascading.flow.planner.ruleCascading
RuleRegistryRuleRegistry contains all planner rules for a given platform.Classcascading.flow.planner.ruleCascading
RuleRegistrySet applied via the FlowPlanner to the given assembly.Classcascading.flow.planner.ruleCascading
RuleRemoveBranchTransformerClasscascading.flow.planner.rule.transformerCascading
RuleReplaceTransformerClasscascading.flow.planner.rule.transformerCascading
RuleResultClasscascading.flow.planner.ruleCascading
RuleSetExecClasscascading.flow.planner.ruleCascading
RuleTransformerThe RuleTransformer class is responsible for transforming an element graph into a new graph.Classcascading.flow.planner.ruleCascading
Sample Where fraction is between 1 and zero, inclusive.Classcascading.operation.filterCascading
SanitizerSanitizer is an interface to be used in conjunction with PropertySanitizer.Interfacecascading.management.annotationCascading
SchemeA Scheme defines what is stored in a Tap instance by declaring the Tuple field names, and alternately parsing or rendering the incoming or outgoing TupleClasscascading.schemeCascading
ScopeClasscascading.flow.plannerCascading
ScopeExpressionIf ScopeExpression is the only edge, the ScopeExpression.Classcascading.flow.planner.iso.expressionCascading
ScriptFilter This Filter is based on the Janino compiler.Classcascading.operation.expressionCascading
ScriptFunction This Function is based on the Janino compiler.Classcascading.operation.expressionCascading
ScriptOperationClasscascading.operation.expressionCascading
ScriptTupleFunction This Function is based on the Janino compiler.Classcascading.operation.expressionCascading
SearchOrderClasscascading.flow.planner.iso.finderCascading
ServiceLoader CascadingService instances used by internal frameworks.Classcascading.providerCascading
SetMultiMapClasscascading.utilCascading
SetValue of a given Filter operation.Classcascading.operation.functionCascading
ShortCoerceClasscascading.tuple.coerceCascading
ShortObjectCoerceClasscascading.tuple.coerceCascading
ShutdownUtilShutdownUtil is a private helper class for registering dependent shutdown hooks to maintain internal state information reliably when a jvm is shutting down.Classcascading.utilCascading
SingleCloseableInputIteratorClasscascading.utilCascading
SingleValueCloseableIteratorSingleValueIterator is a utility class used for quickly presenting a single value to a consumer expecting both a Closeable and an Iterator interface.Classcascading.utilCascading
SingleValueIterator with interfaces that only accept Iterator instances.Classcascading.utilCascading
SinkCallSinkCall provides access to the current Scheme.Interfacecascading.schemeCascading
SinkModeEnum SinkMode identifies supported modes a Tap may utilize when used as a sink.Classcascading.tapCascading
SinkStageClasscascading.flow.stream.elementCascading
SinkTap Some Tap instances may only be sinks (as opposed to being a source).Classcascading.tapCascading
SliceCountersClasscascading.flowCascading
SortedListMultiMapClasscascading.utilCascading
SourceCallSourceCall provides access to the current Scheme.Interfacecascading.schemeCascading
SourceStageClasscascading.flow.stream.elementCascading
SourceTap Some Tap instances may only be sources (as opposed to being a sink).Classcascading.tapCascading
SparseTupleComparatorClasscascading.flow.stream.utilCascading
SpillableInterfacecascading.tuple.collectCascading
SpillableProps FlowConnector before creating new Flow instances.Classcascading.tuple.collectCascading
SpillableTupleList Using a threshold of -1 will disable the spill, all values will remain in memory.Classcascading.tuple.collectCascading
SpillableTupleMapSpillableTupleMap is a HashMap that will allow for multiple values per key, and if the number of values for a given key reach a specific threshold, they will be spilled to disk using a SpillableTupleList instance.Classcascading.tuple.collectCascading
SpliceThe base class for GroupBy, CoGroup, Merge, and HashJoin.Classcascading.pipeCascading
SpliceGateClasscascading.flow.stream.elementCascading
SplicePipeExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
SplitBeforeEveryAssertClasscascading.flow.planner.rule.assertionCascading
SplitBeforeEveryExpressionClasscascading.flow.planner.rule.expressionCascading
StageClasscascading.flow.stream.ductCascading
StatsListenerInterfacecascading.statsCascading
Status the first Tuple it sees.Classcascading.operation.stateCascading
StepCountersEnum StepCounters lists all countersEnum Constant SummaryClasscascading.flowCascading
StreamComparatorThe StreamComparator interface allows for two InputStream instances to be compared, typically bit-wise.Interfacecascading.tupleCascading
StreamGraph Under some circumstances it may make sense to see the actual graph plan.Classcascading.flow.stream.graphCascading
StreamModeClasscascading.flow.stream.annotationsCascading
StringCoerceClasscascading.tuple.coerceCascading
StringEdgeNameProviderClasscascading.util.jgraphtCascading
StringNameProviderClasscascading.util.jgraphtCascading
SubAssemblySubclasses of SubAssembly encapsulate complex assemblies of Pipes so they my be reused in the same manner That is, a typical SubAssembly subclass will accept a 'previous' Pipe instance, and a fewClasscascading.pipeCascading
SubGraphIteratorInterfacecascading.flow.planner.iso.subgraphCascading
SubGraphTransformerClasscascading.flow.planner.iso.transformerCascading
SumClasscascading.operation.aggregatorCascading
SumBy Typically finding the sum of field in a tuple stream relies on a GroupBy and a Sum Aggregator operation.Classcascading.pipe.assemblyCascading
SyncPipeExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
TapA Tap represents the physical data source or sink in a connected Flow.Classcascading.tapCascading
TapException Use the payload Tuple constructor if being thrown from inside a Scheme and which for specific data to be trapped by a failure trap Tap.Classcascading.tapCascading
TapGraphClasscascading.cascade.plannerCascading
TapGroupTapExpressionGraphClasscascading.flow.planner.rule.expressiongraphCascading
TapOrBoundaryElementExpressionClasscascading.flow.planner.rule.elementexpressionCascading
TopologyGraphClasscascading.cascade.plannerCascading
TraceableInterfacecascading.utilCascading
TraceUtilClasscascading.utilCascading
TraceWriterClasscascading.flow.planner.rule.utilCascading
TransformedClasscascading.flow.planner.iso.transformerCascading
TrapExceptionTrapException is a pass through exception allowing trap io failures to propagate past upstream traps.Classcascading.flow.streamCascading
TrapHandlerClasscascading.flow.stream.elementCascading
TrapProps instances used as traps on a given Flow.Classcascading.tapCascading
TupleA Tuple represents a set of values.Classcascading.tupleCascading
TupleBuilderClasscascading.tuple.utilCascading
TupleChainIterableTupleChainIterator chains the given Iterators into a single Iterator.Classcascading.tupleCascading
TupleChainIteratorTupleChainIterator chains the given Iterators into a single Iterator.Classcascading.tupleCascading
TupleCollectionFactory used to back in memory "join" and "co-group" operations.Interfacecascading.tuple.collectCascading
TupleEntry Once a TupleEntry is created, its Fields cannot be changed, but the Tuple instance it holds can be replaced or modified.Classcascading.tupleCascading
TupleEntryChainIteratorTupleEntryChainIterator chains the given Iterators into a single Iterator.Classcascading.tupleCascading
TupleEntryCollector one or more result Tuple values.Classcascading.tupleCascading
TupleEntryIterableChainIteratorTupleEntryChainIterator chains the given Iterators into a single Iterator.Classcascading.tupleCascading
TupleEntryIterator underlying Tuple collection.Classcascading.tupleCascading
TupleEntrySchemeCollector Scheme.Classcascading.tupleCascading
TupleEntrySchemeIterator Scheme.Classcascading.tupleCascading
TupleEntrySchemeIteratorProps TupleEntrySchemeIterator.Classcascading.tupleCascading
TupleExceptionClasscascading.tupleCascading
TupleHasherClasscascading.tuple.utilCascading
TupleInputStreamClasscascading.tuple.ioCascading
TupleListCollectorTupleEntryCollector is a convenience class for managing a list of tuples.Classcascading.tupleCascading
TupleMapFactory used to back in memory "join" and "co-group" operations.Interfacecascading.tuple.collectCascading
TupleOutputStreamClasscascading.tuple.ioCascading
TuplePair part independently.Classcascading.tuple.ioCascading
TuplesClasscascading.tupleCascading
TupleViewsThis class is experimental and for internal use only.Classcascading.tuple.utilCascading
TypeExpressionClasscascading.flow.planner.iso.expressionCascading
UnGroup That is, for the given field positions, this function will emit a new Tuple for every value.Classcascading.operation.functionCascading
Unique Typically finding unique value in a tuple stream relies on a GroupBy and a FirstNBuffer If the include value is set to Unique.Classcascading.pipe.assemblyCascading
UniquePathGraphPartitionerClasscascading.flow.planner.iso.subgraph.partitionerCascading
UniquePathRulePartitioner sub-graphs as initial partitions, then will partition the resulting graph into a unique sub-graph for each unique path between the head and tail of the graph.Classcascading.flow.planner.rule.partitionerCascading
UniquePathSubGraphIteratorClasscascading.flow.planner.iso.subgraph.iteratorCascading
UniquePropsClasscascading.pipe.assemblyCascading
UnitOfWork allowing them to be used interchangeably.Interfacecascading.managementCascading
UnitOfWorkDefClasscascading.propertyCascading
UnitOfWorkExecutorStrategy This is the default spawn strategy.Classcascading.managementCascading
UnitOfWorkSpawnStrategyThe interface UnitOfWorkSpawnStrategy is a strategy for allowing pluggable thread management services into any UnitOfWork class.Interfacecascading.managementCascading
UnsupportedPlanExceptionClasscascading.flow.planner.ruleCascading
UpdateClasscascading.utilCascading
URISanitizerURISanitizer is an implementation of the Sanitizer interface to sanitize URIs of different kinds (file, HTTP, HDFS, JDBC etc.Classcascading.management.annotationCascading
UtilClasscascading.utilCascading
ValueAssertion Implementers must also extend BaseOperation.Interfacecascading.operationCascading
ValueAssertionCallInterfacecascading.operationCascading
ValueAssertionEachStageClasscascading.flow.stream.elementCascading
VersionClasscascading.utilCascading
VisibilityVisibility controls whether a certain Property is visible to a certain PRIVATE - recommended that only a developer or team/project member have access to the valuePROTECTED - recommended for interested and authorized partiesPUBLIC - recommended for use as general purpose informationClasscascading.management.annotationCascading
WholeGraphNodePartitionerClasscascading.flow.planner.rule.partitionerCascading
WholeGraphPartitionerClasscascading.flow.planner.iso.subgraph.partitionerCascading
WholeGraphRulePartitionerClasscascading.flow.planner.rule.partitionerCascading
WholeGraphStepPartitionerClasscascading.flow.planner.rule.partitionerCascading
Xor constructor provided Filter instances.Classcascading.operation.filterCascading