Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.flume Classes and Interfaces - 461 results found.
NameDescriptionTypePackageFramework
AbstractAvroEventSerializerThis is a helper class provided to make it straightforward to serialize Flume events into Avro data.Classorg.apache.flume.serializationFlume
AbstractChannelClassorg.apache.flume.channelFlume
AbstractChannelSelectorClassorg.apache.flume.channelFlume
AbstractConfigurationProviderClassorg.apache.flume.nodeFlume
AbstractElasticSearchIndexRequestBuilderFactoryAbstract base class for custom implementations of ElasticSearchIndexRequestBuilderFactory.Classorg.apache.flume.sink.elasticsearchFlume
AbstractEventDrivenSourceBase class which ensures sub-classes will inherit all the properties of BasicSourceSemantics.Classorg.apache.flume.sourceFlume
AbstractHDFSWriterClassorg.apache.flume.sink.hdfsFlume
AbstractPollableSourceBase class which ensures sub-classes will inherit all the properties of BasicSourceSemantics in addition to:Classorg.apache.flume.sourceFlume
AbstractRpcClientClassorg.apache.flume.apiFlume
AbstractRpcSinkThis sink provides the basic RPC functionality for Flume.Classorg.apache.flume.sinkFlume
AbstractSinkNested Class SummaryNested classes/interfaces inherited from interface org.Classorg.apache.flume.sinkFlume
AbstractSinkProcessorA convenience base class for sink processors.Classorg.apache.flume.sinkFlume
AbstractSinkSelectorClassorg.apache.flume.sinkFlume
AbstractSourceClassorg.apache.flume.sourceFlume
AESCTRNoPaddingProviderClassorg.apache.flume.channel.file.encryptionFlume
AESCTRNoPaddingProvider .DecryptorBuilderFields inherited from class org.Classorg.apache.flume.channel.file.encryption.AESCTRNoPaddingProviderFlume
AESCTRNoPaddingProvider .EncryptorBuilderFields inherited from class org.Classorg.apache.flume.channel.file.encryption.AESCTRNoPaddingProviderFlume
ApplicationClassorg.apache.flume.nodeFlume
AsyncHbaseEventSerializerInterface for an event serializer which serializes the headers and body of an event to write them to hbase.Interfaceorg.apache.flume.sink.hbaseFlume
AsyncHBaseSinkA simple sink which reads events from a channel and writes them to HBase.Classorg.apache.flume.sink.hbaseFlume
AvroCLIClientClassorg.apache.flume.client.avroFlume
AvroEventDeserializerA deserializer that parses Avro container files, generating one Flume event per record in the Avro file, and storing binary avro-encoded records inClassorg.apache.flume.serializationFlume
AvroEventDeserializer .AvroSchemaTypeClassorg.apache.flume.serialization.AvroEventDeserializerFlume
AvroEventDeserializer .BuilderConstructor SummaryAvroEventDeserializer.Classorg.apache.flume.serialization.AvroEventDeserializerFlume
AvroEventSerializer This class serializes Flume events into Avro data files.Classorg.apache.flume.sink.hdfsFlume
AvroEventSerializer .BuilderConstructor SummaryAvroEventSerializer.Classorg.apache.flume.sink.hdfs.AvroEventSerializerFlume
AvroEventSerializerConfigurationConstantsClassorg.apache.flume.serializationFlume
AvroLegacySource A Source implementation that receives Avro events from Avro sink of Configuration optionsClassorg.apache.flume.source.avroLegacyFlume
AvroSink A Sink implementation that can send events to an RPC server (such as Flume's AvroSource).Classorg.apache.flume.sinkFlume
AvroSource A Source implementation that receives Avro events from clients that implement AvroSourceProtocol.Classorg.apache.flume.sourceFlume
BadCheckpointExceptionException thrown when the checkpoint directory contains invalid data, probably due to the channel stopping while the checkpoint was written.Classorg.apache.flume.channel.fileFlume
BasicChannelSemantics An implementation of basic Channel semantics, including the implied thread-local semantics of the Transaction class,Classorg.apache.flume.channelFlume
BasicConfigurationConstantsClassorg.apache.flume.confFlume
BasicSourceSemanticsAlternative to AbstractSource, which: Ensure configure cannot be called while startedExceptions thrown during configure, start, stop put source in ERROR stateExceptions thrown during start, stop will be logged but not re-thrown.Classorg.apache.flume.sourceFlume
BasicTransactionSemantics An implementation of basic Transaction semantics designed to work in concert with BasicChannelSemantics to simplifyClassorg.apache.flume.channelFlume
BasicTransactionSemantics .State The state of the Transaction to which it belongs.Classorg.apache.flume.channel.BasicTransactionSemanticsFlume
BatchAwareThis interface allows for implementing HBase serializers that are aware of batching.Interfaceorg.apache.flume.sink.hbaseFlume
BlobDeserializerA deserializer that reads a Binary Large Object (BLOB) per event, typically one BLOB per file; To be used in conjunction with Flume SpoolDirectorySource.Classorg.apache.flume.sink.solr.morphlineFlume
BlobDeserializer .BuilderBuilder implementations MUST have a public no-arg constructorConstructor SummaryBlobDeserializer.Classorg.apache.flume.sink.solr.morphline.BlobDeserializerFlume
BlobHandlerBlobHandler for HTTPSource that returns event that contains the request parameters as well as the Binary Large Object (BLOB) uploaded with thisClassorg.apache.flume.sink.solr.morphlineFlume
BodyTextEventSerializerThis class simply writes the body of the event to the output stream and appends a newline after each event.Classorg.apache.flume.serializationFlume
BodyTextEventSerializer .BuilderConstructor SummaryBodyTextEventSerializer.Classorg.apache.flume.serialization.BodyTextEventSerializerFlume
BucketClosedExceptionClassorg.apache.flume.sink.hdfsFlume
BucketPathClassorg.apache.flume.formatter.outputFlume
Channel A channel connects a Source to a Sink.Interfaceorg.apache.flumeFlume
ChannelConfigurationClassorg.apache.flume.conf.channelFlume
ChannelConfiguration .ChannelConfigurationTypeClassorg.apache.flume.conf.channel.ChannelConfigurationFlume
ChannelCounterNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.instrumentationFlume
ChannelCounterMBeanThis interface represents a channel counter mbean.Interfaceorg.apache.flume.instrumentationFlume
ChannelExceptionA channel exception is raised whenever a channel operation fails.Classorg.apache.flumeFlume
ChannelFactoryInterfaceorg.apache.flumeFlume
ChannelFullExceptionClassorg.apache.flumeFlume
ChannelProcessorA channel processor exposes operations to put Events into Channels.Classorg.apache.flume.channelFlume
ChannelProcessorCounterNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.instrumentationFlume
ChannelSelector Allows the selection of a subset of channels from the given set based on its implementation policy.Interfaceorg.apache.flumeFlume
ChannelSelectorConfigurationClassorg.apache.flume.conf.channelFlume
ChannelSelectorConfiguration .ChannelSelectorConfigurationTypeClassorg.apache.flume.conf.channel.ChannelSelectorConfigurationFlume
ChannelSelectorFactoryClassorg.apache.flume.channelFlume
ChannelSelectorTypeenum ChannelSelectorTypeextends EnumEnumeration of built in channel selector types available in the system.Classorg.apache.flume.conf.channelFlume
ChannelTypeenum ChannelTypeextends EnumEnumeration of built in channel types available in the system.Classorg.apache.flume.conf.channelFlume
ChannelUtils A collection of utilities for interacting with Channel objects.Classorg.apache.flume.channelFlume
CheckpointRebuilderClassorg.apache.flume.channel.fileFlume
CipherProviderClassorg.apache.flume.channel.file.encryptionFlume
CipherProvider .DecryptorClassorg.apache.flume.channel.file.encryption.CipherProviderFlume
CipherProvider .Decryptor .BuilderClassorg.apache.flume.channel.file.encryption.CipherProvider.DecryptorFlume
CipherProvider .EncryptorClassorg.apache.flume.channel.file.encryption.CipherProviderFlume
CipherProvider .Encryptor .BuilderBuilder implementations MUST have a no-arg constructorConstructor SummaryCipherProvider.Classorg.apache.flume.channel.file.encryption.CipherProvider.EncryptorFlume
CipherProviderFactoryClassorg.apache.flume.channel.file.encryptionFlume
CipherProviderTypeenum CipherProviderTypeextends EnumEnum Constant SummaryAESCTRNOPADDINGClassorg.apache.flume.channel.file.encryptionFlume
ClockFacade for System.Interfaceorg.apache.flumeFlume
ComponentConfigurationAbstract implementation of the Component Configuration Manager.Classorg.apache.flume.confFlume
ComponentConfiguration .ComponentTypeClassorg.apache.flume.conf.ComponentConfigurationFlume
ComponentConfigurationFactoryClassorg.apache.flume.confFlume
Configurable Any class marked as Configurable may have a context including its sub-configuration passed to it, requesting it configure itself.Interfaceorg.apache.flume.confFlume
ConfigurableComponentInterfaceorg.apache.flume.confFlume
ConfigurablesMethods for working with Configurables.Classorg.apache.flume.confFlume
ConfigurationConstantsContains configuration keys used by the JDBC channel implementation.Classorg.apache.flume.channel.jdbcFlume
ConfigurationExceptionClassorg.apache.flume.confFlume
ConfigurationProviderInterfaceorg.apache.flume.nodeFlume
ConstantsClassorg.apache.flumeFlume
ContentBuilderUtilClassorg.apache.flume.sink.elasticsearchFlume
ContextThe context is a key-value store used to pass configuration information throughout the system.Classorg.apache.flumeFlume
CorruptEventExceptionSee Also:Serialized FormConstructor SummaryCorruptEventException()Classorg.apache.flume.channel.fileFlume
CounterGroupUsed for counting events, collecting metrics, etc.Classorg.apache.flumeFlume
DatabaseTypeenum DatabaseTypeextends EnumEnum Constant SummaryDERBYClassorg.apache.flume.channel.jdbcFlume
DecodeErrorPolicyenum DecodeErrorPolicyextends EnumEnum Constant SummaryFAILClassorg.apache.flume.serializationFlume
DecryptionFailureExceptionException that is thrown when the channel is unable to decrypt an even read from the channel.Classorg.apache.flume.channel.file.encryptionFlume
DefaultChannelFactoryClassorg.apache.flume.channelFlume
DefaultJMSMessageConverterConverts BytesMessage, TextMessage, and ObjectMessage to a Flume Event.Classorg.apache.flume.source.jmsFlume
DefaultJMSMessageConverter .BuilderConstructor SummaryDefaultJMSMessageConverter.Classorg.apache.flume.source.jms.DefaultJMSMessageConverterFlume
DefaultSinkFactoryClassorg.apache.flume.sinkFlume
DefaultSinkProcessorDefault sink processor that only accepts a single sink, passing on process results without any additional handling.Classorg.apache.flume.sinkFlume
DefaultSourceFactoryClassorg.apache.flume.sourceFlume
DerbySchemaHandler Schema handler for Derby Database.Classorg.apache.flume.channel.jdbc.implFlume
DirectMemoryUtilsClassorg.apache.flume.toolsFlume
DummyPlaceholder class so the git mirror does not leave out the src/main/java dirConstructor SummaryDummy()Classorg.apache.flumeFlume
DurablePositionTrackerClass that stores object state in an avro container file.Classorg.apache.flume.serializationFlume
ElasticSearchClientInterface for an ElasticSearch client which is responsible for sending bulks of events to ElasticSearch.Interfaceorg.apache.flume.sink.elasticsearch.clientFlume
ElasticSearchClientFactoryInternal ElasticSearch client factory.Classorg.apache.flume.sink.elasticsearch.clientFlume
ElasticSearchDynamicSerializerBasic serializer that serializes the event body and header fields into A best effort will be used to determine the content-type, if it cannot beClassorg.apache.flume.sink.elasticsearchFlume
ElasticSearchEventSerializerInterface for an event serializer which serializes the headers and body of an event to write them to ElasticSearch.Interfaceorg.apache.flume.sink.elasticsearchFlume
ElasticSearchIndexRequestBuilderFactoryInterface for creating ElasticSearch IndexRequestBuilder instances from serialized flume events.Interfaceorg.apache.flume.sink.elasticsearchFlume
ElasticSearchLogStashEventSerializerSerialize flume events into the same format LogStash uses This can be used to send events to ElasticSearch and use clients such asClassorg.apache.flume.sink.elasticsearchFlume
ElasticSearchRestClientRest ElasticSearch client which is responsible for sending bulks of events to ElasticSearch using ElasticSearch HTTP API.Classorg.apache.flume.sink.elasticsearch.clientFlume
ElasticSearchSinkA sink which reads events from a channel and writes them to ElasticSearch based on the work done by https://github.Classorg.apache.flume.sink.elasticsearchFlume
ElasticSearchSinkConstantsClassorg.apache.flume.sink.elasticsearchFlume
ElasticSearchTransportClientClassorg.apache.flume.sink.elasticsearch.clientFlume
EmbeddedAgentEmbeddedAgent gives Flume users the ability to embed simple agents in applications.Classorg.apache.flume.agent.embeddedFlume
EmbeddedAgentConfigurationStores publicly accessible configuration constants and private configuration constants and methods.Classorg.apache.flume.agent.embeddedFlume
EmbeddedSourceSimple source used to allow direct access to the channel for the EmbeddedConstructor SummaryEmbeddedSource()Classorg.apache.flume.agent.embeddedFlume
EncryptionConfigurationClassorg.apache.flume.channel.file.encryptionFlume
EventBasic representation of a data object in Flume.Interfaceorg.apache.flumeFlume
EventBuilderClassorg.apache.flume.eventFlume
EventDeliveryExceptionAn event delivery exception is raised whenever an Event fails to reach at least one of its intended (next-hop) destinations.Classorg.apache.flumeFlume
EventDeserializerEstablishes a contract for reading events stored in arbitrary formats from reliable, resettable streams.Interfaceorg.apache.flume.serializationFlume
EventDeserializer .BuilderKnows how to construct this deserializer.Interfaceorg.apache.flume.serialization.EventDeserializerFlume
EventDeserializerFactoryClassorg.apache.flume.serializationFlume
EventDeserializerTypeenum EventDeserializerTypeextends EnumEnum Constant SummaryAVROClassorg.apache.flume.serializationFlume
EventDrivenSourceA Source that does not need an external driver to poll for events to ingest; it provides its own event-drivenInterfaceorg.apache.flumeFlume
EventDrivenSourceRunnerStarts, stops, and manages event-driven sources.Classorg.apache.flume.sourceFlume
EventHelperClassorg.apache.flume.eventFlume
EventReaderA line reader produces a stream of lines for the AvroCLIClient to ingest into Flume.Interfaceorg.apache.flume.client.avroFlume
EventSerDeA class that is able to both serialize and deserialize events.Interfaceorg.apache.flume.serializationFlume
EventSerDe .BuilderKnows how to construct this serde.Interfaceorg.apache.flume.serialization.EventSerDeFlume
EventSerializer This interface provides callbacks for important serialization-related events.Interfaceorg.apache.flume.serializationFlume
EventSerializer .BuilderKnows how to construct this event serializer.Interfaceorg.apache.flume.serialization.EventSerializerFlume
EventSerializerFactoryClassorg.apache.flume.serializationFlume
EventSerializerIndexRequestBuilderFactoryDefault implementation of ElasticSearchIndexRequestBuilderFactory.Classorg.apache.flume.sink.elasticsearchFlume
EventSerializerTypeenum EventSerializerTypeextends EnumEnum Constant SummaryAVRO_EVENTClassorg.apache.flume.serializationFlume
ExecSource A Source implementation that executes a Unix process and turns each line of text into an event.Classorg.apache.flume.sourceFlume
ExecSourceConfigurationConstantsClassorg.apache.flume.sourceFlume
FailoverRpcClientAvro/Netty implementation of RpcClient which supports failover.Classorg.apache.flume.apiFlume
FailoverSinkProcessorFailoverSinkProcessor maintains a prioritized list of sinks, guarranteeing that so long as one is available events will be processed.Classorg.apache.flume.sinkFlume
FileChannel A durable Channel implementation that uses the local file system for FileChannel works by writing all transactions to a set of directoriesClassorg.apache.flume.channel.fileFlume
FileChannelConfigurationClassorg.apache.flume.channel.fileFlume
FileChannelIntegrityToolClassorg.apache.flume.toolsFlume
FlumeConfiguration FlumeConfiguration is an in memory representation of the hierarchical configuration namespace required by the ConfigurationProvider.Classorg.apache.flume.confFlume
FlumeConfiguration .AgentConfigurationClassorg.apache.flume.conf.FlumeConfigurationFlume
FlumeConfiguration .ComponentNameAndConfigKeyClassorg.apache.flume.conf.FlumeConfigurationFlume
FlumeConfigurationErrorClassorg.apache.flume.confFlume
FlumeConfigurationError .ErrorOrWarningClassorg.apache.flume.conf.FlumeConfigurationErrorFlume
FlumeConfigurationErrorTypeenum FlumeConfigurationErrorTypeextends EnumEnum Constant SummaryAGENT_CONFIGURATION_INVALIDClassorg.apache.flume.confFlume
FlumeEventAvroEventSerializerClassorg.apache.flume.serializationFlume
FlumeEventAvroEventSerializer .BuilderConstructor SummaryFlumeEventAvroEventSerializer.Classorg.apache.flume.serialization.FlumeEventAvroEventSerializerFlume
FlumeExceptionBase class of all flume exceptions.Classorg.apache.flumeFlume
FlumeToolInterfaceorg.apache.flume.toolsFlume
FlumeToolsMainClassorg.apache.flume.toolsFlume
FlumeToolTypeenum FlumeToolTypeextends EnumEnum Constant SummaryFCINTEGRITYTOOLClassorg.apache.flume.toolsFlume
GangliaServerA Ganglia server that polls JMX based at a configured frequency (defaults to once every 60 seconds).Classorg.apache.flume.instrumentationFlume
GetJavaPropertyA generic way for querying Java properties.Classorg.apache.flume.toolsFlume
HbaseEventSerializerInterface for an event serializer which serializes the headers and body of an event to write them to hbase.Interfaceorg.apache.flume.sink.hbaseFlume
HBaseSinkA simple sink which reads events from a channel and writes them to HBase.Classorg.apache.flume.sink.hbaseFlume
HBaseSinkConfigurationConstantsClassorg.apache.flume.sink.hbaseFlume
HBaseSinkSecurityManagerClass to handle logging into HBase with the credentials passed in.Classorg.apache.flume.sink.hbaseFlume
HDFSCompressedDataStreamClassorg.apache.flume.sink.hdfsFlume
HDFSDataStreamClassorg.apache.flume.sink.hdfsFlume
HDFSEventSinkClassorg.apache.flume.sink.hdfsFlume
HDFSSequenceFileClassorg.apache.flume.sink.hdfsFlume
HDFSTextSerializerClassorg.apache.flume.sink.hdfsFlume
HDFSTextSerializer .BuilderConstructor SummaryHDFSTextSerializer.Classorg.apache.flume.sink.hdfs.HDFSTextSerializerFlume
HDFSWritableSerializerClassorg.apache.flume.sink.hdfsFlume
HDFSWritableSerializer .BuilderConstructor SummaryHDFSWritableSerializer.Classorg.apache.flume.sink.hdfs.HDFSWritableSerializerFlume
HDFSWriterInterfaceorg.apache.flume.sink.hdfsFlume
HDFSWriterFactoryClassorg.apache.flume.sink.hdfsFlume
HeaderAndBodyTextEventSerializerThis class simply writes the body of the event to the output stream and appends a newline after each event.Classorg.apache.flume.serializationFlume
HeaderAndBodyTextEventSerializer .BuilderConstructor SummaryHeaderAndBodyTextEventSerializer.Classorg.apache.flume.serialization.HeaderAndBodyTextEventSerializerFlume
HostInfoA convenience class that holds the property reference name along with the hostname and port number of a specified host address.Classorg.apache.flume.apiFlume
HostInterceptorSimple Interceptor class that sets the host name or IP on all events that are intercepted.Classorg.apache.flume.interceptorFlume
HostInterceptor .BuilderBuilder which builds new instances of the HostInterceptor.Classorg.apache.flume.interceptor.HostInterceptorFlume
HostInterceptor .ConstantsClassorg.apache.flume.interceptor.HostInterceptorFlume
HTTPBadRequestExceptionException thrown by an HTTP Handler if the request was not parsed correctly into an event because the request was not in the expected format.Classorg.apache.flume.source.httpFlume
HTTPMetricsServerA Monitor service implementation that runs a web server on a configurable port and returns the metrics for components in JSON format.Classorg.apache.flume.instrumentation.httpFlume
HTTPServerConstraintUtilClassorg.apache.flume.toolsFlume
HTTPSourceA source which accepts Flume Events by HTTP POST and GET.Classorg.apache.flume.source.httpFlume
HTTPSourceConfigurationConstantsClassorg.apache.flume.source.httpFlume
HTTPSourceHandlerInterfaceorg.apache.flume.source.httpFlume
IndexNameBuilderInterfaceorg.apache.flume.sink.elasticsearchFlume
InitialContextFactoryClassorg.apache.flume.source.jmsFlume
InterceptorInterfaceorg.apache.flume.interceptorFlume
Interceptor .BuilderBuilder implementations MUST have a no-arg constructorMethods inherited from interface org.Interfaceorg.apache.flume.interceptor.InterceptorFlume
InterceptorBuilderFactoryFactory used to register instances of Interceptors & their builders, as well as to instantiate the builders.Classorg.apache.flume.interceptorFlume
InterceptorChainNested Class SummaryNested classes/interfaces inherited from interface org.Classorg.apache.flume.interceptorFlume
InterceptorTypeenum InterceptorTypeextends EnumEnum Constant SummaryHOSTClassorg.apache.flume.interceptorFlume
InterfaceAudienceAnnotation to inform users of a package, class or method's intended audience.Classorg.apache.flume.annotationsFlume
InterfaceAudience .LimitedPrivateIntended only for the project(s) specified in the annotation.Classorg.apache.flume.annotations.InterfaceAudienceFlume
InterfaceStabilityAnnotation to inform users of how much to rely on a particular package, class or method not changing over time.Classorg.apache.flume.annotationsFlume
IRCSinkClassorg.apache.flume.sink.ircFlume
IRCSink .IRCConnectionListenerFields inherited from interface org.Classorg.apache.flume.sink.irc.IRCSinkFlume
JCEFileKeyProviderClassorg.apache.flume.channel.file.encryptionFlume
JCEFileKeyProvider .BuilderConstructor SummaryJCEFileKeyProvider.Classorg.apache.flume.channel.file.encryption.JCEFileKeyProviderFlume
JdbcChannel A JDBC based channel implementation.Classorg.apache.flume.channel.jdbcFlume
JdbcChannelExceptionClassorg.apache.flume.channel.jdbcFlume
JdbcChannelProviderService provider interface for JDBC channel providers.Interfaceorg.apache.flume.channel.jdbcFlume
JdbcChannelProviderFactoryClassorg.apache.flume.channel.jdbcFlume
JdbcChannelProviderImplClassorg.apache.flume.channel.jdbc.implFlume
JdbcTransactionFactoryClassorg.apache.flume.channel.jdbc.implFlume
JdbcTransactionImplNested Class SummaryNested classes/interfaces inherited from interface org.Classorg.apache.flume.channel.jdbc.implFlume
JMSDestinationLocatorenum JMSDestinationLocatorextends EnumEnum Constant SummaryCDIClassorg.apache.flume.source.jmsFlume
JMSDestinationTypeenum JMSDestinationTypeextends EnumEnum Constant SummaryQUEUEClassorg.apache.flume.source.jmsFlume
JMSMessageConsumerFactoryConstructor SummaryJMSMessageConsumerFactory()Methods inherited from class java.Classorg.apache.flume.source.jmsFlume
JMSMessageConverterConverts a JMS Message to an Event.Interfaceorg.apache.flume.source.jmsFlume
JMSMessageConverter .Builder a suitable builder or implement the Configurable interface.Interfaceorg.apache.flume.source.jms.JMSMessageConverterFlume
JMSSourceNested Class SummaryNested classes/interfaces inherited from interface org.Classorg.apache.flume.source.jmsFlume
JMSSourceConfigurationClassorg.apache.flume.source.jmsFlume
JMXPollUtilClassorg.apache.flume.instrumentation.utilFlume
JSONEventClassorg.apache.flume.eventFlume
JSONHandlerJSONHandler for HTTPSource that accepts an array of events.Classorg.apache.flume.source.httpFlume
KerberosUserSimple Pair class used to define a unique (principal, keyTab) combination.Classorg.apache.flume.sink.hdfsFlume
KeyProviderClassorg.apache.flume.channel.file.encryptionFlume
KeyProviderFactoryClassorg.apache.flume.channel.file.encryptionFlume
KeyProviderTypeenum KeyProviderTypeextends EnumEnum Constant SummaryJCEKSFILEClassorg.apache.flume.channel.file.encryptionFlume
LengthMeasurableInterfaceorg.apache.flume.serializationFlume
LifecycleAware An interface implemented by any class that has a defined, stateful, Implementations of LifecycleAware conform to a standard method ofInterfaceorg.apache.flume.lifecycleFlume
LifecycleControllerClassorg.apache.flume.lifecycleFlume
LifecycleExceptionSee Also:Serialized FormConstructor SummaryLifecycleException()Classorg.apache.flume.lifecycleFlume
LifecycleStateenum LifecycleStateextends EnumEnum Constant SummaryERRORClassorg.apache.flume.lifecycleFlume
LifecycleSupervisorClassorg.apache.flume.lifecycleFlume
LifecycleSupervisor .MonitorRunnableClassorg.apache.flume.lifecycle.LifecycleSupervisorFlume
LifecycleSupervisor .StatusClassorg.apache.flume.lifecycle.LifecycleSupervisorFlume
LifecycleSupervisor .SupervisorPolicyClassorg.apache.flume.lifecycle.LifecycleSupervisorFlume
LifecycleSupervisor .SupervisorPolicy .AlwaysRestartPolicyNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicyFlume
LifecycleSupervisor .SupervisorPolicy .OnceOnlyPolicyNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicyFlume
LineDeserializerA deserializer that parses text lines from a file.Classorg.apache.flume.serializationFlume
LineDeserializer .BuilderConstructor SummaryLineDeserializer.Classorg.apache.flume.serialization.LineDeserializerFlume
LoadBalancingLog4jAppenderAppends Log4j Events to an external Flume client which is decribed by the Log4j configuration file.Classorg.apache.flume.clients.log4jappenderFlume
LoadBalancingRpcClientAn implementation of RpcClient interface that uses NettyAvroRpcClient instances to load-balance the requests over many different hosts.Classorg.apache.flume.apiFlume
LoadBalancingRpcClient .HostSelectorInterfaceorg.apache.flume.api.LoadBalancingRpcClientFlume
LoadBalancingSinkProcessorProvides the ability to load-balance flow over multiple sinks.Classorg.apache.flume.sinkFlume
LoadBalancingSinkProcessor .SinkSelector An interface that allows the LoadBalancingSinkProcessor to use a load-balancing strategy such as round-robin, random distribution etc.Interfaceorg.apache.flume.sink.LoadBalancingSinkProcessorFlume
LogStores FlumeEvents on disk and pointers to the events in a in memory queue.Classorg.apache.flume.channel.fileFlume
Log4jAppenderAppends Log4j Events to an external Flume client which is decribed by the Log4j configuration file.Classorg.apache.flume.clients.log4jappenderFlume
Log4jAvroHeadersenum Log4jAvroHeadersextends EnumEnum Constant SummaryAVRO_SCHEMA_LITERALClassorg.apache.flume.clients.log4jappenderFlume
LogEntryClassorg.apache.flume.source.scribeFlume
LogEntry ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.source.scribe.LogEntryFlume
LogFileClassorg.apache.flume.channel.fileFlume
LogFile .OperationRecordUpdaterThis is an class meant to be an internal Flume API, and can change at any time.Classorg.apache.flume.channel.file.LogFileFlume
LogFile .SequentialReaderClassorg.apache.flume.channel.file.LogFileFlume
LogFileRetryableIOExceptionSee Also:Serialized FormConstructor SummaryLogFileRetryableIOException()Classorg.apache.flume.channel.fileFlume
LogFileV3Represents a single data file on disk.Classorg.apache.flume.channel.fileFlume
LogFileV3 .SequentialReaderConstructor SummaryLogFileV3.Classorg.apache.flume.channel.file.LogFileV3Flume
LoggerSink A Sink implementation that logs all events received at the INFO level to the org.Classorg.apache.flume.sinkFlume
LogRecordClassorg.apache.flume.channel.fileFlume
LogUtilsConstructor SummaryLogUtils()Methods inherited from class java.Classorg.apache.flume.channel.fileFlume
MaterializedConfigurationMaterializedConfiguration represents the materialization of a Flume properties file.Interfaceorg.apache.flume.nodeFlume
MemoryChannel MemoryChannel is the recommended channel to use when speeds which writing to disk is impractical is required or durability of data is notClassorg.apache.flume.channelFlume
MonitoredCounterGroupUsed for keeping track of internal metrics using atomic integers This is used by a variety of component types such as Sources, Channels,Classorg.apache.flume.instrumentationFlume
MonitoredCounterGroup .TypeComponent Enum Constants Used by each component's constructor to distinguish which type theClassorg.apache.flume.instrumentation.MonitoredCounterGroupFlume
MonitoringTypeenum MonitoringTypeextends EnumEnum for Monitoring types.Classorg.apache.flume.instrumentationFlume
MonitorServiceInterface that any monitoring service should implement.Interfaceorg.apache.flume.instrumentationFlume
MorphlineHandlerInterfaceorg.apache.flume.sink.solr.morphlineFlume
MorphlineHandlerImplA MorphlineHandler that processes it's events using a morphline Command chain.Classorg.apache.flume.sink.solr.morphlineFlume
MorphlineInterceptorFlume Interceptor that executes a morphline on events that are intercepted.Classorg.apache.flume.sink.solr.morphlineFlume
MorphlineInterceptor .BuilderBuilder implementations MUST have a public no-arg constructorConstructor SummaryMorphlineInterceptor.Classorg.apache.flume.sink.solr.morphline.MorphlineInterceptorFlume
MorphlineSinkClassorg.apache.flume.sink.solr.morphlineFlume
MorphlineSolrSinkFlume sink that extracts search documents from Flume events, processes them using a morphline Command chain, and loads them into Apache Solr.Classorg.apache.flume.sink.solr.morphlineFlume
MultiplexingChannelSelectorClassorg.apache.flume.channelFlume
MultiportSyslogTCPSourceClassorg.apache.flume.sourceFlume
MySQLSchemaHandlerClassorg.apache.flume.channel.jdbc.implFlume
NamedComponentEnables a component to be tagged with a name so that it can be referred to uniquely within the configuration system.Interfaceorg.apache.flumeFlume
NetcatSource A netcat-like source that listens on a given port and turns each line of text This source, primarily built for testing and exceedingly simple systems, actsClassorg.apache.flume.sourceFlume
NetcatSourceConfigurationConstantsClassorg.apache.flume.sourceFlume
NettyAvroRpcClientAvro/Netty implementation of RpcClient.Classorg.apache.flume.apiFlume
NoopRecordExceptionSee Also:Serialized FormConstructor SummaryNoopRecordException()Classorg.apache.flume.channel.fileFlume
NullSink A Sink implementation that simply discards all events it receives.Classorg.apache.flume.sinkFlume
OrderSelectorA basic implementation of an order selector that implements a simple exponential backoff algorithm.Classorg.apache.flume.utilFlume
PathManagerClassorg.apache.flume.formatter.outputFlume
PersistableEventClassorg.apache.flume.channel.jdbc.implFlume
PersistableEvent .BuilderConstructor SummaryPersistableEvent.Classorg.apache.flume.channel.jdbc.impl.PersistableEventFlume
PersistableEvent .HeaderEntryConstructor SummaryPersistableEvent.Classorg.apache.flume.channel.jdbc.impl.PersistableEventFlume
PersistableEvent .SpillableStringConstructor SummaryPersistableEvent.Classorg.apache.flume.channel.jdbc.impl.PersistableEventFlume
PlatformDetectUtilities for platform & operating system detectionConstructor SummaryPlatformDetect()Classorg.apache.flume.toolsFlume
PollableSourceA Source that requires an external driver to poll to determine whether there are events that are available to ingestInterfaceorg.apache.flumeFlume
PollableSource .StatusClassorg.apache.flume.PollableSourceFlume
PollableSourceRunner An implementation of SourceRunner that can drive a A PollableSourceRunner wraps a PollableSource in the requiredClassorg.apache.flume.sourceFlume
PollableSourceRunner .PollingRunnerConstructor SummaryPollableSourceRunner.Classorg.apache.flume.source.PollableSourceRunnerFlume
PollingPropertiesFileConfigurationProviderClassorg.apache.flume.nodeFlume
PositionTrackerDefines an interface for tracking the offset position in a target file.Interfaceorg.apache.flume.serializationFlume
PropertiesFileConfigurationProvider A configuration provider that uses properties file for specifying configuration.Classorg.apache.flume.nodeFlume
ProtosFactoryClassorg.apache.flume.channel.file.protoFlume
ProtosFactory .ActiveLogProtobuf type ActiveLogSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .ActiveLog .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.ActiveLogFlume
ProtosFactory .ActiveLogOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .CheckpointProtobuf type CheckpointSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .Checkpoint .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.CheckpointFlume
ProtosFactory .CheckpointOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .CommitProtobuf type CommitSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .Commit .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.CommitFlume
ProtosFactory .CommitOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .FlumeEventProtobuf type FlumeEventSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .FlumeEvent .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.FlumeEventFlume
ProtosFactory .FlumeEventHeaderProtobuf type FlumeEventHeaderSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .FlumeEventHeader .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.FlumeEventHeaderFlume
ProtosFactory .FlumeEventHeaderOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .FlumeEventOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .LogFileEncryptionProtobuf type LogFileEncryptionSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .LogFileEncryption .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.LogFileEncryptionFlume
ProtosFactory .LogFileEncryptionOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .LogFileMetaDataProtobuf type LogFileMetaDataSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .LogFileMetaData .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.LogFileMetaDataFlume
ProtosFactory .LogFileMetaDataOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .PutClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .Put .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.PutFlume
ProtosFactory .PutOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .RollbackProtobuf type RollbackSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .Rollback .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.RollbackFlume
ProtosFactory .RollbackOrBuilderMethods inherited from interface com.Interfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .TakeClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .Take .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.TakeFlume
ProtosFactory .TakeOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .TransactionEventFooterProtobuf type TransactionEventFooterSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .TransactionEventFooter .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.TransactionEventFooterFlume
ProtosFactory .TransactionEventFooterOrBuilderMethods inherited from interface com.Interfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .TransactionEventHeaderProtobuf type TransactionEventHeaderSee Also:Serialized FormClassorg.apache.flume.channel.file.proto.ProtosFactoryFlume
ProtosFactory .TransactionEventHeader .BuilderClassorg.apache.flume.channel.file.proto.ProtosFactory.TransactionEventHeaderFlume
ProtosFactory .TransactionEventHeaderOrBuilderInterfaceorg.apache.flume.channel.file.proto.ProtosFactoryFlume
PseudoTxnMemoryChannel A capacity-capped Channel implementation that supports in-memory buffering and delivery of events.Classorg.apache.flume.channelFlume
PseudoTxnMemoryChannel .NoOpTransaction A no-op transaction implementation that does nothing at all.Classorg.apache.flume.channel.PseudoTxnMemoryChannelFlume
RandomOrderSelectorAn implementation of OrderSelector which returns objects in random order.Classorg.apache.flume.utilFlume
RegexExtractorInterceptorInterceptor that extracts matches using a specified regular expression and appends the matches to the event headers using the specified serializersClassorg.apache.flume.interceptorFlume
RegexExtractorInterceptor .BuilderConstructor SummaryRegexExtractorInterceptor.Classorg.apache.flume.interceptor.RegexExtractorInterceptorFlume
RegexExtractorInterceptorMillisSerializerSerializer that converts the passed in value into milliseconds using the specified formatting patternClassorg.apache.flume.interceptorFlume
RegexExtractorInterceptorPassThroughSerializerSerializer that simply returns the passed in valueConstructor SummaryRegexExtractorInterceptorPassThroughSerializer()Classorg.apache.flume.interceptorFlume
RegexExtractorInterceptorSerializerSerializer for serializing groups matched by the RegexExtractorInterceptorInterfaceorg.apache.flume.interceptorFlume
RegexFilteringInterceptorInterceptor that filters events selectively based on a configured regular expression matching against the event body.Classorg.apache.flume.interceptorFlume
RegexFilteringInterceptor .BuilderBuilder which builds new instance of the StaticInterceptor.Classorg.apache.flume.interceptor.RegexFilteringInterceptorFlume
RegexFilteringInterceptor .ConstantsClassorg.apache.flume.interceptor.RegexFilteringInterceptorFlume
RegexHbaseEventSerializerAn HbaseEventSerializer which parses columns based on a supplied regular expression and column name list.Classorg.apache.flume.sink.hbaseFlume
ReliableEventReaderA reliable event reader.Interfaceorg.apache.flume.client.avroFlume
ReliableSpoolingFileEventReaderA ReliableEventReader which reads log data from files stored in a spooling directory and renames each file once all of its data has beenClassorg.apache.flume.client.avroFlume
ReliableSpoolingFileEventReader .BuilderSpecial builder class for ReliableSpoolingFileEventReaderConstructor SummaryReliableSpoolingFileEventReader.Classorg.apache.flume.client.avro.ReliableSpoolingFileEventReaderFlume
RemoteMarkableInterfaceorg.apache.flume.serializationFlume
ReplicatingChannelSelectorReplicating channel selector.Classorg.apache.flume.channelFlume
ResettableDefines an API for objects that can be mark()ed and reset() on arbitrary boundaries.Interfaceorg.apache.flume.serializationFlume
ResettableFileInputStreamThis class makes the following assumptions: The underlying file is not changing while it is being readClassorg.apache.flume.serializationFlume
ResettableInputStream This abstract class defines an interface for which the stream may be marked and reset with no limit toClassorg.apache.flume.serializationFlume
ResultCodeenum ResultCodeextends Enumimplements org.Classorg.apache.flume.source.scribeFlume
RollingFileSinkNested Class SummaryNested classes/interfaces inherited from interface org.Classorg.apache.flume.sinkFlume
RoundRobinListClassorg.apache.flume.sink.elasticsearch.clientFlume
RoundRobinOrderSelectorAn implementation of OrderSelector which returns objects in round robin order.Classorg.apache.flume.utilFlume
RpcClientPublic client interface for sending data to Flume.Interfaceorg.apache.flume.apiFlume
RpcClientConfigurationConstantsConfiguration constants used by the RpcClient.Classorg.apache.flume.apiFlume
RpcClientFactoryFactory class to construct Flume RPCClient implementations.Classorg.apache.flume.apiFlume
RpcClientFactory .ClientTypeClassorg.apache.flume.api.RpcClientFactoryFlume
SchemaHandlerA handler for creating and validating database schema for use by the JDBC channel implementation.Interfaceorg.apache.flume.channel.jdbc.implFlume
SchemaHandlerFactoryA factory for SchemaHandlers.Classorg.apache.flume.channel.jdbc.implFlume
ScribeClassorg.apache.flume.source.scribeFlume
Scribe .AsyncClientClassorg.apache.flume.source.scribe.ScribeFlume
Scribe .AsyncClient .FactoryConstructor SummaryScribe.Classorg.apache.flume.source.scribe.Scribe.AsyncClientFlume
Scribe .AsyncClient .Log_callNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.source.scribe.Scribe.AsyncClientFlume
Scribe .AsyncIfaceInterfaceorg.apache.flume.source.scribe.ScribeFlume
Scribe .ClientClassorg.apache.flume.source.scribe.ScribeFlume
Scribe .Client .FactoryConstructor SummaryScribe.Classorg.apache.flume.source.scribe.Scribe.ClientFlume
Scribe .IfaceInterfaceorg.apache.flume.source.scribe.ScribeFlume
Scribe .Log_argsClassorg.apache.flume.source.scribe.ScribeFlume
Scribe .Log_args ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.source.scribe.Scribe.Log_argsFlume
Scribe .Log_resultClassorg.apache.flume.source.scribe.ScribeFlume
Scribe .Log_result ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.source.scribe.Scribe.Log_resultFlume
Scribe .ProcessorClassorg.apache.flume.source.scribe.ScribeFlume
ScribeSourceFlume should adopt the Scribe entry LogEntry from existing Scribe system.Classorg.apache.flume.source.scribeFlume
SeekableInterfaceorg.apache.flume.serializationFlume
SequenceFileSerializerInterfaceorg.apache.flume.sink.hdfsFlume
SequenceFileSerializer .BuilderKnows how to construct this output formatter.Interfaceorg.apache.flume.sink.hdfs.SequenceFileSerializerFlume
SequenceFileSerializer .RecordA key-value pair making up a record in an HDFS SequenceFileConstructor SummarySequenceFileSerializer.Classorg.apache.flume.sink.hdfs.SequenceFileSerializerFlume
SequenceFileSerializerFactoryConstructor SummarySequenceFileSerializerFactory()Methods inherited from class java.Classorg.apache.flume.sink.hdfsFlume
SequenceFileSerializerTypeenum SequenceFileSerializerTypeextends EnumEnum Constant SummaryOtherClassorg.apache.flume.sink.hdfsFlume
SequenceGeneratorSourceNested Class SummaryNested classes/interfaces inherited from interface org.Classorg.apache.flume.sourceFlume
SerializationClassorg.apache.flume.channel.fileFlume
SimpleAsyncHbaseEventSerializerA simple serializer to be used with the AsyncHBaseSink that returns puts from an event, by writing the eventClassorg.apache.flume.sink.hbaseFlume
SimpleEventClassorg.apache.flume.eventFlume
SimpleHbaseEventSerializerA simple serializer that returns puts from an event, by writing the event body into it.Classorg.apache.flume.sink.hbaseFlume
SimpleHbaseEventSerializer .KeyTypeClassorg.apache.flume.sink.hbase.SimpleHbaseEventSerializerFlume
SimpleIndexNameBuilderClassorg.apache.flume.sink.elasticsearchFlume
SimpleMaterializedConfigurationClassorg.apache.flume.nodeFlume
SimpleRowKeyGeneratorUtility class for users to generate their own keys.Classorg.apache.flume.sink.hbaseFlume
SimpleTextLineEventReaderClassorg.apache.flume.client.avroFlume
Sink A sink is connected to a Channel and consumes its contents, sending them to a configured destination that may vary according toInterfaceorg.apache.flumeFlume
Sink .StatusClassorg.apache.flume.SinkFlume
SinkConfigurationClassorg.apache.flume.conf.sinkFlume
SinkConfiguration .SinkConfigurationTypeClassorg.apache.flume.conf.sink.SinkConfigurationFlume
SinkCounterNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.instrumentationFlume
SinkCounterMBeanThis interface represents a sink counter mbean.Interfaceorg.apache.flume.instrumentationFlume
SinkFactoryInterfaceorg.apache.flumeFlume
SinkGroupConfiguration concept for handling multiple sinks working together.Classorg.apache.flume.sinkFlume
SinkGroupConfigurationNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.conf.sinkFlume
SinkProcessor Interface for a device that allows abstraction of the behavior of multiple sinks, always assigned to a SinkRunnerInterfaceorg.apache.flumeFlume
SinkProcessorConfigurationClassorg.apache.flume.conf.sinkFlume
SinkProcessorConfiguration .SinkProcessorConfigurationTypeClassorg.apache.flume.conf.sink.SinkProcessorConfigurationFlume
SinkProcessorCounterNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.instrumentationFlume
SinkProcessorFactoryClassorg.apache.flume.sinkFlume
SinkProcessorTypeenum SinkProcessorTypeextends EnumEnum Constant SummaryDEFAULTClassorg.apache.flume.conf.sinkFlume
SinkRunner A driver for sinks that polls them, attempting to process events if any are available in theClassorg.apache.flumeFlume
SinkRunner .PollingRunnerRunnable that polls a SinkProcessor and manages event delivery notification,Classorg.apache.flume.SinkRunnerFlume
SinkTypeenum SinkTypeextends EnumEnumeration of built in sink types available in the system.Classorg.apache.flume.conf.sinkFlume
Source A source generates and calls methods on the configured ChannelProcessor to persist those events into theInterfaceorg.apache.flumeFlume
SourceConfigurationClassorg.apache.flume.conf.sourceFlume
SourceConfiguration .SourceConfigurationTypeClassorg.apache.flume.conf.source.SourceConfigurationFlume
SourceCounterNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.instrumentationFlume
SourceCounterMBeanThis interface represents a source counter mbean.Interfaceorg.apache.flume.instrumentationFlume
SourceFactoryInterfaceorg.apache.flumeFlume
SourceRunnerA source runner controls how a source is driven.Classorg.apache.flumeFlume
SourceTypeenum SourceTypeextends EnumEnumeration of built in source types available in the system.Classorg.apache.flume.conf.sourceFlume
SpecificOrderIteratorA utility class that iterates over the given ordered list of items via the specified order array.Classorg.apache.flume.utilFlume
SpillableMemoryChannel SpillableMemoryChannel will use main memory for buffering events until it has reached capacity.Classorg.apache.flume.channelFlume
SpillableMemoryChannel .DrainOrderQueueClassorg.apache.flume.channel.SpillableMemoryChannelFlume
SpoolDirectorySourceClassorg.apache.flume.sourceFlume
SpoolDirectorySourceConfigurationConstantsClassorg.apache.flume.sourceFlume
SpoolDirectorySourceConfigurationConstants .ConsumeOrderClassorg.apache.flume.source.SpoolDirectorySourceConfigurationConstantsFlume
StaticInterceptorInterceptor class that appends a static, pre-configured header to all events.Classorg.apache.flume.interceptorFlume
StaticInterceptor .BuilderBuilder which builds new instance of the StaticInterceptor.Classorg.apache.flume.interceptor.StaticInterceptorFlume
StaticInterceptor .ConstantsClassorg.apache.flume.interceptor.StaticInterceptorFlume
Statusenum Statusextends Enumimplements org.Classorg.apache.flume.thriftFlume
StressSourceInternal load-generating source implementation.Classorg.apache.flume.sourceFlume
SyslogParserClassorg.apache.flume.sourceFlume
SyslogSourceConfigurationConstantsClassorg.apache.flume.sourceFlume
SyslogTcpSourceClassorg.apache.flume.sourceFlume
SyslogUDPSourceClassorg.apache.flume.sourceFlume
SyslogUtilsClassorg.apache.flume.sourceFlume
SyslogUtils .SyslogStatusClassorg.apache.flume.source.SyslogUtilsFlume
SystemClockDefault implementation of Clock which uses SystemConstructor SummarySystemClock()Classorg.apache.flumeFlume
TextDelimitedOutputFormatterClassorg.apache.flume.formatter.outputFlume
ThriftFlumeEventClassorg.apache.flume.thriftFlume
ThriftFlumeEvent ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.thrift.ThriftFlumeEventFlume
ThriftLegacySourceClassorg.apache.flume.source.thriftLegacyFlume
ThriftLegacySource .ThriftHandlerConstructor SummaryThriftLegacySource.Classorg.apache.flume.source.thriftLegacy.ThriftLegacySourceFlume
ThriftRpcClientFields inherited from class org.Classorg.apache.flume.apiFlume
ThriftSink A Sink implementation that can send events to an RPC server (such as Flume's ThriftSource).Classorg.apache.flume.sinkFlume
ThriftSourceClassorg.apache.flume.sourceFlume
ThriftSourceProtocolClassorg.apache.flume.thriftFlume
ThriftSourceProtocol .append_argsClassorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .append_args ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.thrift.ThriftSourceProtocol.append_argsFlume
ThriftSourceProtocol .append_resultClassorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .append_result ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.thrift.ThriftSourceProtocol.append_resultFlume
ThriftSourceProtocol .appendBatch_argsClassorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .appendBatch_args ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.thrift.ThriftSourceProtocol.appendBatch_argsFlume
ThriftSourceProtocol .appendBatch_resultClassorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .appendBatch_result ._FieldsThe set of fields this struct contains, along with convenience methods for finding and manipulating them.Classorg.apache.flume.thrift.ThriftSourceProtocol.appendBatch_resultFlume
ThriftSourceProtocol .AsyncClientClassorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .AsyncClient .append_callNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.thrift.ThriftSourceProtocol.AsyncClientFlume
ThriftSourceProtocol .AsyncClient .appendBatch_callNested Class SummaryNested classes/interfaces inherited from class org.Classorg.apache.flume.thrift.ThriftSourceProtocol.AsyncClientFlume
ThriftSourceProtocol .AsyncClient .FactoryConstructor SummaryThriftSourceProtocol.Classorg.apache.flume.thrift.ThriftSourceProtocol.AsyncClientFlume
ThriftSourceProtocol .AsyncIfaceInterfaceorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .ClientClassorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .Client .FactoryConstructor SummaryThriftSourceProtocol.Classorg.apache.flume.thrift.ThriftSourceProtocol.ClientFlume
ThriftSourceProtocol .IfaceInterfaceorg.apache.flume.thrift.ThriftSourceProtocolFlume
ThriftSourceProtocol .ProcessorClassorg.apache.flume.thrift.ThriftSourceProtocolFlume
TimeBasedIndexNameBuilderDefault index name builder.Classorg.apache.flume.sink.elasticsearchFlume
TimestampInterceptorSimple Interceptor class that sets the current system timestamp on all events that are intercepted.Classorg.apache.flume.interceptorFlume
TimestampInterceptor .BuilderBuilder which builds new instances of the TimestampInterceptor.Classorg.apache.flume.interceptor.TimestampInterceptorFlume
TimestampInterceptor .ConstantsClassorg.apache.flume.interceptor.TimestampInterceptorFlume
TimestampRoundDownUtilClassorg.apache.flume.toolsFlume
TransactionProvides the transaction boundary while accessing a channel.Interfaceorg.apache.flumeFlume
Transaction .TransactionStateClassorg.apache.flume.TransactionFlume
TransactionEventRecordClassorg.apache.flume.channel.fileFlume
TransactionIDOracleClassorg.apache.flume.channel.fileFlume
TransactionIsolationenum TransactionIsolationextends EnumEnum Constant SummaryREAD_COMMITTEDClassorg.apache.flume.channel.jdbcFlume
TwitterSourceDemo Flume source that connects via Streaming API to the 1% sample twitter firehose, continously downloads tweets, converts them to Avro format andClassorg.apache.flume.source.twitterFlume
UUIDInterceptorFlume Interceptor that sets a universally unique identifier on all events that are intercepted.Classorg.apache.flume.sink.solr.morphlineFlume
UUIDInterceptor .BuilderBuilder implementations MUST have a public no-arg constructorConstructor SummaryUUIDInterceptor.Classorg.apache.flume.sink.solr.morphline.UUIDInterceptorFlume
VersionAnnotationThis class is about package attribute that captures version info of Flume that was compiled.Classorg.apache.flumeFlume
VersionInfoClassorg.apache.flume.toolsFlume
WriteOrderOracleClassorg.apache.flume.channel.fileFlume