A B C D E F G H I J L M N O P Q R S T U V W

A

abort() - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
AbstractChannel - Class in org.apache.flume.channel
 
AbstractChannel() - Constructor for class org.apache.flume.channel.AbstractChannel
 
AbstractChannelSelector - Class in org.apache.flume.channel
 
AbstractChannelSelector() - Constructor for class org.apache.flume.channel.AbstractChannelSelector
 
AbstractFileConfigurationProvider - Class in org.apache.flume.conf.file
 
AbstractFileConfigurationProvider() - Constructor for class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
AbstractFileConfigurationProvider.FileWatcherRunnable - Class in org.apache.flume.conf.file
 
AbstractFileConfigurationProvider.FileWatcherRunnable() - Constructor for class org.apache.flume.conf.file.AbstractFileConfigurationProvider.FileWatcherRunnable
 
AbstractLogicalNodeManager - Class in org.apache.flume.node.nodemanager
 
AbstractLogicalNodeManager() - Constructor for class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
AbstractSink - Class in org.apache.flume.sink
 
AbstractSink() - Constructor for class org.apache.flume.sink.AbstractSink
 
AbstractSource - Class in org.apache.flume.source
 
AbstractSource() - Constructor for class org.apache.flume.source.AbstractSource
 
activateOptions() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Activate the options set using setPort() and setHostname()
add(CounterGroup) - Method in class org.apache.flume.CounterGroup
 
add(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
add(LifecycleAware) - Method in interface org.apache.flume.node.NodeManager
 
add(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
addAndGet(String, Long) - Method in class org.apache.flume.CounterGroup
 
append(AvroFlumeOGEvent) - Method in interface com.cloudera.flume.handlers.avro.FlumeOGEventAvroServer
 
append(AvroFlumeOGEvent, Callback<Void>) - Method in interface com.cloudera.flume.handlers.avro.FlumeOGEventAvroServer.Callback
 
append(ThriftFlumeEvent, <any>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
Deprecated.  
append(ThriftFlumeEvent, <any>) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
Deprecated.  
append(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
append(ThriftFlumeEvent) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
Deprecated.  
append(Event) - Method in class org.apache.flume.api.NettyAvroRpcClient
 
append(Event) - Method in interface org.apache.flume.api.RpcClient
Send a single Event to the associated Flume source.
append(LoggingEvent) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Append the LoggingEvent, to send to the first Flume hop.
append(Event) - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
append(Event, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
append(Event, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
append(Event, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
append(Event, FlumeFormatter) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
append(AvroFlumeEvent) - Method in interface org.apache.flume.source.avro.AvroSourceProtocol
 
append(AvroFlumeEvent, Callback<Status>) - Method in interface org.apache.flume.source.avro.AvroSourceProtocol.Callback
 
append(AvroFlumeOGEvent) - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
append(AvroFlumeEvent) - Method in class org.apache.flume.source.AvroSource
 
appendBatch(List<Event>) - Method in class org.apache.flume.api.NettyAvroRpcClient
 
appendBatch(List<Event>) - Method in interface org.apache.flume.api.RpcClient
Send a list of events to the associated Flume source.
appendBatch(List<AvroFlumeEvent>) - Method in interface org.apache.flume.source.avro.AvroSourceProtocol
 
appendBatch(List<AvroFlumeEvent>, Callback<Status>) - Method in interface org.apache.flume.source.avro.AvroSourceProtocol.Callback
 
appendBatch(List<AvroFlumeEvent>) - Method in class org.apache.flume.source.AvroSource
 
Application - Class in org.apache.flume.node
 
Application() - Constructor for class org.apache.flume.node.Application
 
AvroCLIClient - Class in org.apache.flume.client.avro
 
AvroCLIClient() - Constructor for class org.apache.flume.client.avro.AvroCLIClient
 
avroClient - Variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
AvroFlumeEvent - Class in org.apache.flume.source.avro
 
AvroFlumeEvent() - Constructor for class org.apache.flume.source.avro.AvroFlumeEvent
 
AvroFlumeEvent.Builder - Class in org.apache.flume.source.avro
RecordBuilder for AvroFlumeEvent instances.
AvroFlumeOGEvent - Class in com.cloudera.flume.handlers.avro
 
AvroFlumeOGEvent() - Constructor for class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
 
AvroFlumeOGEvent.Builder - Class in com.cloudera.flume.handlers.avro
RecordBuilder for AvroFlumeOGEvent instances.
AvroLegacySource - Class in org.apache.flume.source.avroLegacy
A Source implementation that receives Avro events from Avro sink of Flume OG
AvroLegacySource() - Constructor for class org.apache.flume.source.avroLegacy.AvroLegacySource
 
AvroSink - Class in org.apache.flume.sink
A Sink implementation that can send events to an RPC server (such as Flume's AvroSource).
AvroSink() - Constructor for class org.apache.flume.sink.AvroSink
 
AvroSource - Class in org.apache.flume.source
A Source implementation that receives Avro events from clients that implement AvroSourceProtocol.
AvroSource() - Constructor for class org.apache.flume.source.AvroSource
 
AvroSourceProtocol - Interface in org.apache.flume.source.avro
 
AvroSourceProtocol.Callback - Interface in org.apache.flume.source.avro
 

B

BasicChannelSemantics - Class in org.apache.flume.channel
An implementation of basic Channel semantics, including the implied thread-local semantics of the Transaction class, which is required to extend BasicTransactionSemantics.
BasicChannelSemantics() - Constructor for class org.apache.flume.channel.BasicChannelSemantics
 
BasicTransactionSemantics - Class in org.apache.flume.channel
An implementation of basic Transaction semantics designed to work in concert with BasicChannelSemantics to simplify creation of robust Channel implementations.
BasicTransactionSemantics() - Constructor for class org.apache.flume.channel.BasicTransactionSemantics
 
BasicTransactionSemantics.State - Enum in org.apache.flume.channel
The state of the Transaction to which it belongs.
batchSize(Integer) - Method in class org.apache.flume.api.NettyAvroRpcClient.Builder
Maximum number of events that can be processed in a batch operation.
begin() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
begin() - Method in class org.apache.flume.channel.file.FileChannel.FileBackedTransaction
 
begin() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
begin() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
begin() - Method in interface org.apache.flume.Transaction
Starts a transaction boundary for the current channel operation.
body - Variable in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Deprecated. 
body - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
body - Variable in class org.apache.flume.source.avro.AvroFlumeEvent
Deprecated. 
BucketPath - Class in org.apache.flume.formatter.output
 
BucketPath() - Constructor for class org.apache.flume.formatter.output.BucketPath
 
BucketWriter - Class in org.apache.flume.sink.hdfs
 
BucketWriter(long, long, long, long) - Constructor for class org.apache.flume.sink.hdfs.BucketWriter
 
BucketWriter.BucketFlushStatus - Enum in org.apache.flume.sink.hdfs
 
bufferForBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
build() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
 
build() - Method in class org.apache.flume.api.NettyAvroRpcClient.Builder
Construct the object
build() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
build() - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
 

C

Channel - Interface in org.apache.flume
A channel connects a Source to a Sink.
CHANNEL_NAME_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The maximum length of channel name.
ChannelException - Exception in org.apache.flume
A channel exception is raised whenever a channel operation fails.
ChannelException(String) - Constructor for exception org.apache.flume.ChannelException
 
ChannelException(Throwable) - Constructor for exception org.apache.flume.ChannelException
 
ChannelException(String, Throwable) - Constructor for exception org.apache.flume.ChannelException
 
ChannelFactory - Interface in org.apache.flume
 
ChannelProcessor - Class in org.apache.flume.channel
A channel processor exposes operations to put Events into Channels.
ChannelProcessor(ChannelSelector) - Constructor for class org.apache.flume.channel.ChannelProcessor
 
ChannelSelector - Interface in org.apache.flume
Allows the selection of a subset of channels from the given set based on its implementation policy.
ChannelSelectorFactory - Class in org.apache.flume.channel
 
ChannelSelectorFactory() - Constructor for class org.apache.flume.channel.ChannelSelectorFactory
 
ChannelSelectorType - Enum in org.apache.flume.channel
Enumeration of built in channel selector types available in the system.
ChannelType - Enum in org.apache.flume.channel
Enumeration of built in channel types available in the system.
ChannelUtils - Class in org.apache.flume.channel
A collection of utilities for interacting with Channel objects.
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
clear() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
clear() - Method in class org.apache.flume.Context
Removes all of the mappings from this map.
clearBody() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Clears the value of the 'body' field
clearBody() - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Clears the value of the 'body' field
clearFields() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Clears the value of the 'fields' field
clearHeaders() - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Clears the value of the 'headers' field
clearHost() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Clears the value of the 'host' field
clearNanos() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Clears the value of the 'nanos' field
clearPriority() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Clears the value of the 'priority' field
clearTimestamp() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Clears the value of the 'timestamp' field
close(<any>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
Deprecated.  
close(<any>) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncIface
Deprecated.  
close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
close() - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Iface
Deprecated.  
close() - Method in class org.apache.flume.api.NettyAvroRpcClient
 
close() - Method in interface org.apache.flume.api.RpcClient
Immediately closes the client so that it may no longer be used.
close() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
close() - Method in class org.apache.flume.channel.file.FileChannel.FileBackedTransaction
 
close() - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
close() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
close() - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Deinitializes the channel provider.
close() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
close() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Closes underlying client.
close() - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
close() - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
close() - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
close() - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
close() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
close() - Method in interface org.apache.flume.Transaction
Ends a transaction boundary for the current channel operation.
COLUMN_LOOKUP_QUERY - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
com.cloudera.flume.handlers.avro - package com.cloudera.flume.handlers.avro
 
com.cloudera.flume.handlers.thrift - package com.cloudera.flume.handlers.thrift
 
commit() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
commit() - Method in class org.apache.flume.channel.file.FileChannel.FileBackedTransaction
 
commit() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
commit() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
commit() - Method in interface org.apache.flume.Transaction
Indicates that the transaction can be successfully committed.
compareTo(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
compareTo(ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
compareTo(ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
compareTo(ThriftFlumeEventServer.close_result) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
CONFIG_CREATE_INDEX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_CREATE_SCHEMA - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_DATABASE_TYPE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_JDBC_DRIVER_CLASS - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_JDBC_PROPERTIES_FILE - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_JDBC_SYSPRO_PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_MAX_CAPACITY - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_MAX_CONNECTION - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_MULTIPLEX_HEADER_NAME - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
CONFIG_PASSWORD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_PREFIX_DEFAULT - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
CONFIG_PREFIX_MAPPING - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
CONFIG_TX_ISOLATION_LEVEL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_URL - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
CONFIG_USERNAME - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
Configurable - Interface in org.apache.flume.conf
 
Configurables - Class in org.apache.flume.conf
Methods for working with Configurables.
Configurables() - Constructor for class org.apache.flume.conf.Configurables
 
ConfigurationConstants - Class in org.apache.flume.channel.jdbc
Contains configuration keys used by the JDBC channel implementation.
ConfigurationProvider - Interface in org.apache.flume.node
 
configure(Context) - Method in class org.apache.flume.channel.AbstractChannel
 
configure(Context) - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
configure(Context) - Method in class org.apache.flume.channel.MemoryChannel
 
configure(Context) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
 
configure(Context) - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
configure(Context) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
 
configure(Context) - Method in interface org.apache.flume.conf.Configurable
 
configure(Object, Context) - Static method in class org.apache.flume.conf.Configurables
Check that target implements Configurable and, if so, ask it to configure itself using the supplied context.
configure(Context) - Method in class org.apache.flume.sink.AvroSink
 
configure(Context) - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
configure(Context) - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
configure(Context) - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
 
configure(Context) - Method in class org.apache.flume.sink.irc.IRCSink
 
configure(Context) - Method in class org.apache.flume.sink.RollingFileSink
 
configure(Context) - Method in class org.apache.flume.sink.SinkGroup
 
configure(Context) - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
configure(Context) - Method in class org.apache.flume.source.AvroSource
 
configure(Context) - Method in class org.apache.flume.source.ExecSource
 
configure(Context) - Method in class org.apache.flume.source.NetcatSource
 
configure(Context) - Method in class org.apache.flume.source.SyslogTcpSource
 
configure(Context) - Method in class org.apache.flume.source.SyslogUDPSource
 
configure(Context) - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
Constants - Class in org.apache.flume
 
containsTag(String) - Static method in class org.apache.flume.formatter.output.BucketPath
Returns true if in contains a substring matching TAG_REGEX (i.e.
Context - Class in org.apache.flume
The context is a key-value store used to pass configuration information throughout the system.
Context() - Constructor for class org.apache.flume.Context
 
Context(Map<String, String>) - Constructor for class org.apache.flume.Context
 
CounterGroup - Class in org.apache.flume
Used for counting events, collecting metrics, etc.
CounterGroup() - Constructor for class org.apache.flume.CounterGroup
 
create(List<Channel>, Map<String, String>) - Static method in class org.apache.flume.channel.ChannelSelectorFactory
 
create(String, String) - Method in class org.apache.flume.channel.DefaultChannelFactory
 
create(String, String) - Method in interface org.apache.flume.ChannelFactory
 
create(String, String) - Method in class org.apache.flume.sink.DefaultSinkFactory
 
create(String, String) - Method in interface org.apache.flume.SinkFactory
 
create(String, String) - Method in class org.apache.flume.source.DefaultSourceFactory
 
create(String, String) - Method in interface org.apache.flume.SourceFactory
 
createSchemaObjects(boolean) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
createSchemaObjects(boolean) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
createSchemaObjects(boolean) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Creates the schema.
createTransaction() - Method in class org.apache.flume.channel.BasicChannelSemantics
Called to create new Transaction objects, which must extend BasicTransactionSemantics.
createTransaction() - Method in class org.apache.flume.channel.MemoryChannel
 

D

DatabaseType - Enum in org.apache.flume.channel.jdbc
 
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
deepCopy() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
DEFAULT_BATCH_SIZE - Static variable in class org.apache.flume.api.NettyAvroRpcClient.Builder
 
DEFAULT_MULTIPLEX_HEADER - Static variable in class org.apache.flume.channel.MultiplexingChannelSelector
 
DefaultChannelFactory - Class in org.apache.flume.channel
 
DefaultChannelFactory() - Constructor for class org.apache.flume.channel.DefaultChannelFactory
 
DefaultLogicalNodeManager - Class in org.apache.flume.node.nodemanager
 
DefaultLogicalNodeManager() - Constructor for class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
DefaultSinkFactory - Class in org.apache.flume.sink
 
DefaultSinkFactory() - Constructor for class org.apache.flume.sink.DefaultSinkFactory
 
DefaultSinkProcessor - Class in org.apache.flume.sink
Default sink processor that only accepts a single sink, passing on process results without any additional handling.
DefaultSinkProcessor() - Constructor for class org.apache.flume.sink.DefaultSinkProcessor
 
DefaultSourceFactory - Class in org.apache.flume.source
 
DefaultSourceFactory() - Constructor for class org.apache.flume.source.DefaultSourceFactory
 
DerbySchemaHandler - Class in org.apache.flume.channel.jdbc.impl
Schema handler for Derby Database.
DerbySchemaHandler(DataSource) - Constructor for class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
desiredState - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
discard - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
doBegin() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doClose() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doCommit() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doCommit() - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
doPut(Event) - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doPut(Event) - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
doRollback() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doRollback() - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
doTake() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
doTake() - Method in class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 

E

ensureOptionalNonNull(Context, String...) - Static method in class org.apache.flume.conf.Configurables
 
ensureRequiredNonNull(Context, String...) - Static method in class org.apache.flume.conf.Configurables
 
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
equals(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
equals(ThriftFlumeEventServer.append_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
equals(ThriftFlumeEventServer.close_args) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
equals(Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
equals(ThriftFlumeEventServer.close_result) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
escapeString(String, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
Replace all substrings of form %{tagname} with get(tagname).toString() and all shorthand substrings of form %x with a special value.
Event - Interface in org.apache.flume
Basic representation of a data object in Flume.
EventBuilder - Class in org.apache.flume.event
 
EventBuilder() - Constructor for class org.apache.flume.event.EventBuilder
 
EventDeliveryException - Exception in org.apache.flume
An event delivery exception is raised whenever an Event fails to reach at least one of its intended (next-hop) destinations.
EventDeliveryException() - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDeliveryException(String) - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDeliveryException(String, Throwable) - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDeliveryException(Throwable) - Constructor for exception org.apache.flume.EventDeliveryException
 
EventDrivenSource - Interface in org.apache.flume
A Source that does not need an external driver to poll for events to ingest; it provides its own event-driven mechanism to invoke event processing.
EventDrivenSourceRunner - Class in org.apache.flume.source
Starts, stops, and manages event-driven sources.
EventDrivenSourceRunner() - Constructor for class org.apache.flume.source.EventDrivenSourceRunner
 
EventFormatter - Interface in org.apache.flume.formatter.output
 
EventStatus - Enum in com.cloudera.flume.handlers.thrift
 
evt - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
ExecSource - Class in org.apache.flume.source
A Source implementation that executes a Unix process and turns each line of text into an event.
ExecSource() - Constructor for class org.apache.flume.source.ExecSource
 
expandShorthand(char) - Static method in class org.apache.flume.formatter.output.BucketPath
 
extractEvent(ChannelBuffer) - Static method in class org.apache.flume.source.SyslogUtils
 

F

fail() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
FailoverSinkProcessor - Class in org.apache.flume.sink
FailoverSinkProcessor is in no way thread safe and expects to be run via SinkRunner Additionally, setSinks must be called before configure, and additional sinks cannot be added while running To configure, set a sink groups processor to "failover" and set priorities for individual sinks: Ex) host1.sinkgroups = group1 host1.sinkgroups.group1.sinks = sink1 sink2 host1.sinkgroups.group1.processor.type = failover host1.sinkgroups.group1.processor.priority.sink1 = 5 host1.sinkgroups.group1.processor.priority.sink2 = 10
FailoverSinkProcessor() - Constructor for class org.apache.flume.sink.FailoverSinkProcessor
 
failures - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
fetchAndDeleteEvent(String, Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
fetchAndDeleteEvent(String, Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
fetchAndDeleteEvent(String, Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Retrieves the next persistent event from the database.
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
fieldForId(int) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
fields - Variable in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Deprecated. 
fields - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
FileChannel - Class in org.apache.flume.channel.file
A durable Channel implementation that uses the local file system for its storage.
FileChannel() - Constructor for class org.apache.flume.channel.file.FileChannel
 
FileChannel.FileBackedTransaction - Class in org.apache.flume.channel.file
An implementation of Transaction for FileChannels.
FileChannel.FileBackedTransaction() - Constructor for class org.apache.flume.channel.file.FileChannel.FileBackedTransaction
 
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated. Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated. Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated. Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated. Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated. Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated. Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated. Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated. Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated. Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated. Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated. Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated. Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.cloudera.flume.handlers.thrift.Priority
Find a the enum type by its integer value, as defined in the Thrift IDL.
firstSeen - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
FlumeConfiguration - Class in org.apache.flume.conf.properties
FlumeConfiguration is an in memory representation of the hierarchical configuration namespace required by the PropertiesFileConfgurationProvider.
FlumeConfiguration(Properties) - Constructor for class org.apache.flume.conf.properties.FlumeConfiguration
Creates an empty Flume Configuration object.
FlumeConfiguration.AgentConfiguration - Class in org.apache.flume.conf.properties
 
FlumeConfiguration.ComponentConfiguration - Class in org.apache.flume.conf.properties
 
FlumeConfiguration.ComponentNameAndConfigKey - Class in org.apache.flume.conf.properties
 
FlumeException - Exception in org.apache.flume
Base class of all flume exceptions.
FlumeException(String) - Constructor for exception org.apache.flume.FlumeException
 
FlumeException(String, Throwable) - Constructor for exception org.apache.flume.FlumeException
 
FlumeException(Throwable) - Constructor for exception org.apache.flume.FlumeException
 
FlumeFormatter - Interface in org.apache.flume.sink
 
FlumeNode - Class in org.apache.flume.node
 
FlumeNode() - Constructor for class org.apache.flume.node.FlumeNode
 
FlumeOGEventAvroServer - Interface in com.cloudera.flume.handlers.avro
 
FlumeOGEventAvroServer.Callback - Interface in com.cloudera.flume.handlers.avro
 
flush() - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
format(Event) - Method in interface org.apache.flume.formatter.output.EventFormatter
 
format(Event) - Method in class org.apache.flume.formatter.output.TextDelimitedOutputFormatter
 
forSource(Source) - Static method in class org.apache.flume.SourceRunner
Static factory method to instantiate a source runner implementation that corresponds to the type of Source specified.

G

get(int) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
 
get(String) - Method in class org.apache.flume.CounterGroup
 
get(int) - Method in class org.apache.flume.source.avro.AvroFlumeEvent
 
getAllChannels() - Method in class org.apache.flume.channel.AbstractChannelSelector
 
getAllChannels() - Method in interface org.apache.flume.ChannelSelector
 
getArgs() - Method in class org.apache.flume.node.Application
 
getAsyncClient(org.apache.thrift.transport.TNonblockingTransport) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
Deprecated.  
getBase() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
getBaseDirectory() - Method in class org.apache.flume.formatter.output.PathManager
 
getBasePayload() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getBatchSize() - Method in class org.apache.flume.api.NettyAvroRpcClient
 
getBatchSize() - Method in interface org.apache.flume.api.RpcClient
Returns the maximum number of events that may be batched at once by appendBatch().
getBody() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Gets the value of the 'body' field
getBody() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Gets the value of the 'body' field.
getBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getBody() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getBody() - Method in interface org.apache.flume.Event
Returns the raw byte array of the data contained in this event.
getBody() - Method in class org.apache.flume.event.SimpleEvent
 
getBody() - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Gets the value of the 'body' field
getBody() - Method in class org.apache.flume.source.avro.AvroFlumeEvent
Gets the value of the 'body' field.
getBoolean(String, Boolean) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getBoolean(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
getByName(String) - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
 
getByName(String) - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
getByName(String) - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
 
getBytes(Event) - Method in interface org.apache.flume.sink.FlumeFormatter
 
getBytes(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getBytes(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getChannel() - Method in class org.apache.flume.sink.AbstractSink
 
getChannel() - Method in interface org.apache.flume.Sink
 
getChannelClassName() - Method in enum org.apache.flume.channel.ChannelType
 
getChannelFactory() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getChannelName() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getChannelProcessor() - Method in class org.apache.flume.source.AbstractSource
 
getChannelProcessor() - Method in interface org.apache.flume.Source
Returns the channel processor that will handle this source's events.
getChannels() - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
getChannels() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.AgentConfiguration
 
getChannels() - Method in interface org.apache.flume.node.NodeConfiguration
 
getChannelSelectorClassName() - Method in enum org.apache.flume.channel.ChannelSelectorType
 
getChannelSize(Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
getChannelSize(Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
getChannelSize(Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Returns the current size of the channel using the connection specified that must have an active transaction ongoing.
getClient(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
Deprecated.  
getClient(org.apache.thrift.protocol.TProtocol, org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
Deprecated.  
getCode() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
getCompleteDirectory() - Method in class org.apache.flume.channel.file.FileChannel
 
getComponentName() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.ComponentConfiguration
 
getComponentName() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.ComponentNameAndConfigKey
 
getConfigKey() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.ComponentNameAndConfigKey
 
getConfiguration() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.ComponentConfiguration
 
getConfigurationAware() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getConfigurationFor(String) - Method in class org.apache.flume.conf.properties.FlumeConfiguration
 
getConfigurationProvider() - Method in class org.apache.flume.node.FlumeNode
 
getConnection() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
getCounter(String) - Method in class org.apache.flume.CounterGroup
 
getCounters() - Method in class org.apache.flume.CounterGroup
 
getCurrentFile() - Method in class org.apache.flume.formatter.output.PathManager
 
getDirectory() - Method in class org.apache.flume.channel.file.FileChannel
 
getDirectory() - Method in class org.apache.flume.sink.RollingFileSink
 
getEscapeMapping(String, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
Instead of replacing escape sequences in a string, this method returns a mapping of an attribute name to the value based on the escape sequence found in the argument string.
getEventId() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated.  
getFieldName() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated.  
getFields() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Gets the value of the 'fields' field
getFields() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Gets the value of the 'fields' field.
getFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getFieldsSize() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getFieldValue(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getFieldValue(ThriftFlumeEventServer.append_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
getFieldValue(ThriftFlumeEventServer.close_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
getFieldValue(ThriftFlumeEventServer.close_result._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
getFile() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getFileIndex() - Method in class org.apache.flume.formatter.output.PathManager
 
getFilePath() - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
getFormatter() - Method in class org.apache.flume.sink.RollingFileSink
 
getHandler(DatabaseType, DataSource) - Static method in class org.apache.flume.channel.jdbc.impl.SchemaHandlerFactory
 
getHeaderEntries() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getHeaders() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getHeaders() - Method in interface org.apache.flume.Event
Returns a map of name-value pairs describing the data stored in the body.
getHeaders() - Method in class org.apache.flume.event.SimpleEvent
 
getHeaders() - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Gets the value of the 'headers' field
getHeaders() - Method in class org.apache.flume.source.avro.AvroFlumeEvent
Gets the value of the 'headers' field.
getHost() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Gets the value of the 'host' field
getHost() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Gets the value of the 'host' field.
getHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getId() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getInputProtocol() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
getInstance(String, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Returns an instance of RpcClient connected to the specified hostname and port.
getInstance(String, Integer, Integer) - Static method in class org.apache.flume.api.RpcClientFactory
Returns an instance of RpcClient connected to the specified hostname and port with the specified batchSize.
getInteger(String, Integer) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getInteger(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
getKey(Event) - Method in interface org.apache.flume.sink.FlumeFormatter
 
getKey(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getKey(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getKeyClass() - Method in interface org.apache.flume.sink.FlumeFormatter
 
getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getKeyClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getLifecycleState() - Method in class org.apache.flume.channel.AbstractChannel
 
getLifecycleState() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getLifecycleState() - Method in interface org.apache.flume.lifecycle.LifecycleAware
Return the current state of the service or component.
getLifecycleState() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
getLifecycleState() - Method in class org.apache.flume.node.FlumeNode
 
getLifecycleState() - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
getLifecycleState() - Method in class org.apache.flume.sink.AbstractSink
 
getLifecycleState() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
getLifecycleState() - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
getLifecycleState() - Method in class org.apache.flume.SinkRunner
 
getLifecycleState() - Method in class org.apache.flume.source.AbstractSource
 
getLifecycleState() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
getLifecycleState() - Method in class org.apache.flume.source.PollableSourceRunner
 
getLong(String, Long) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getLong(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
getName() - Method in class org.apache.flume.channel.AbstractChannel
 
getName() - Method in class org.apache.flume.channel.AbstractChannelSelector
 
getName() - Method in class org.apache.flume.channel.file.FileChannel
 
getName() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
 
getName() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getName() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
getName() - Method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
 
getName() - Method in class org.apache.flume.CounterGroup
 
getName() - Method in interface org.apache.flume.NamedComponent
 
getName() - Method in class org.apache.flume.node.FlumeNode
 
getName() - Method in class org.apache.flume.sink.AbstractSink
 
getName() - Method in class org.apache.flume.source.AbstractSource
 
getNameString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getNanos() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Gets the value of the 'nanos' field
getNanos() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Gets the value of the 'nanos' field.
getNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getNodeManager() - Method in class org.apache.flume.node.FlumeNode
 
getNodeName() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getNodes() - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
getNodes() - Method in interface org.apache.flume.node.NodeManager
 
getOpenDirectory() - Method in class org.apache.flume.channel.file.FileChannel
 
getOptionalChannels(Event) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
 
getOptionalChannels(Event) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
 
getOptionalChannels(Event) - Method in interface org.apache.flume.ChannelSelector
Returns a list of optional channels.
getOutputProtocol() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
getParameters() - Method in class org.apache.flume.Context
Gets a copy of the backing map structure.
getPolicy() - Method in class org.apache.flume.SinkRunner
 
getPriority() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Gets the value of the 'priority' field
getPriority() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Gets the value of the 'priority' field.
getPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getProcessor() - Method in class org.apache.flume.sink.SinkGroup
 
getProcessor(Context, List<Sink>) - Static method in class org.apache.flume.sink.SinkProcessorFactory
Creates a sink processor and configures it using the provided context
getProvider(Context, String) - Static method in class org.apache.flume.channel.jdbc.JdbcChannelProviderFactory
 
getRegistryClone() - Method in class org.apache.flume.channel.DefaultChannelFactory
 
getRegistryClone() - Method in class org.apache.flume.sink.DefaultSinkFactory
 
getRegistryClone() - Method in class org.apache.flume.source.DefaultSourceFactory
 
getRequiredChannels(Event) - Method in class org.apache.flume.channel.MultiplexingChannelSelector
 
getRequiredChannels(Event) - Method in class org.apache.flume.channel.ReplicatingChannelSelector
 
getRequiredChannels(Event) - Method in interface org.apache.flume.ChannelSelector
Returns a list of required channels.
getResult() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
Deprecated.  
getResult() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
Deprecated.  
getRollInterval() - Method in class org.apache.flume.sink.RollingFileSink
 
getSchema() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
 
getSchema() - Method in class org.apache.flume.source.avro.AvroFlumeEvent
 
getSelector() - Method in class org.apache.flume.channel.ChannelProcessor
 
getSeriesTimestamp() - Method in class org.apache.flume.formatter.output.PathManager
 
getSinkClassName() - Method in enum org.apache.flume.sink.SinkType
 
getSinkFactory() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getSinkGroups() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.AgentConfiguration
 
getSinkProcessorClassName() - Method in enum org.apache.flume.SinkProcessorType
 
getSinkRunners() - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
getSinkRunners() - Method in interface org.apache.flume.node.NodeConfiguration
 
getSinks() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.AgentConfiguration
 
getSource() - Method in class org.apache.flume.SourceRunner
 
getSourceClassName() - Method in enum org.apache.flume.source.SourceType
 
getSourceFactory() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
getSourceRunners() - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
getSourceRunners() - Method in interface org.apache.flume.node.NodeConfiguration
 
getSources() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.AgentConfiguration
 
getSpill() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
getSpillPayload() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
getState() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
getString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
getString(String, String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning defaultValue if unmapped.
getString(String) - Method in class org.apache.flume.Context
Gets value mapped to key, returning null if unmapped.
getSubconfiguration(String) - Method in class org.apache.flume.conf.properties.FlumeConfiguration.ComponentConfiguration
 
getSubProperties(String) - Method in class org.apache.flume.Context
Get properties which start with a prefix.
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated.  
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated.  
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated.  
getThriftFieldId() - Method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated.  
getTimestamp() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Gets the value of the 'timestamp' field
getTimestamp() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
getTransaction() - Method in class org.apache.flume.channel.BasicChannelSemantics
Initializes the channel if it is not already, then checks to see if there is an open transaction for this thread, creating a new one via createTransaction if not.
getTransaction() - Method in class org.apache.flume.channel.file.FileChannel
 
getTransaction() - Method in interface org.apache.flume.Channel
 
getTransaction() - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
getTransaction() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
getTransaction() - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
 
getTransaction() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
getValidationQuery() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
 
getValue() - Method in enum com.cloudera.flume.handlers.thrift.EventStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.cloudera.flume.handlers.thrift.Priority
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getValue(Event) - Method in interface org.apache.flume.sink.FlumeFormatter
 
getValue(Event) - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getValue(Event) - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getValueClass() - Method in interface org.apache.flume.sink.FlumeFormatter
 
getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
getValueClass() - Method in class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
getValueString() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
getWriter(String) - Method in class org.apache.flume.sink.hdfs.HDFSWriterFactory
 

H

hasBody() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Checks whether the 'body' field has been set
hasBody() - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Checks whether the 'body' field has been set
hasFields() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Checks whether the 'fields' field has been set
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
hashCode() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
hasHeaders() - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Checks whether the 'headers' field has been set
hasHost() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Checks whether the 'host' field has been set
hasNanos() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Checks whether the 'nanos' field has been set
hasPriority() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Checks whether the 'priority' field has been set
hasSpill() - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
hasTimestamp() - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Checks whether the 'timestamp' field has been set
HDFSCompressedDataStream - Class in org.apache.flume.sink.hdfs
 
HDFSCompressedDataStream() - Constructor for class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
HDFSDataStream - Class in org.apache.flume.sink.hdfs
 
HDFSDataStream() - Constructor for class org.apache.flume.sink.hdfs.HDFSDataStream
 
HDFSEventSink - Class in org.apache.flume.sink.hdfs
 
HDFSEventSink() - Constructor for class org.apache.flume.sink.hdfs.HDFSEventSink
 
HDFSEventSink(HDFSWriterFactory) - Constructor for class org.apache.flume.sink.hdfs.HDFSEventSink
 
HDFSFormatterFactory - Class in org.apache.flume.sink.hdfs
 
HDFSSequenceFile - Class in org.apache.flume.sink.hdfs
 
HDFSSequenceFile() - Constructor for class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
HDFSTextFormatter - Class in org.apache.flume.sink.hdfs
 
HDFSTextFormatter() - Constructor for class org.apache.flume.sink.hdfs.HDFSTextFormatter
 
HDFSWritableFormatter - Class in org.apache.flume.sink.hdfs
 
HDFSWritableFormatter() - Constructor for class org.apache.flume.sink.hdfs.HDFSWritableFormatter
 
HDFSWriter - Interface in org.apache.flume.sink.hdfs
 
HDFSWriterFactory - Class in org.apache.flume.sink.hdfs
 
HDFSWriterFactory() - Constructor for class org.apache.flume.sink.hdfs.HDFSWriterFactory
 
HEADER_NAME_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The length of header name in bytes that will be stored inline.
HEADER_NAME_SPILL_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The maximum spill size for header names.
HEADER_VALUE_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The length of header value in bytes that will be stored inline.
HEADER_VALUE_SPILL_MAX_LENGTH - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The maximum spill size for header values.
headers - Variable in class org.apache.flume.source.avro.AvroFlumeEvent
Deprecated. 
host - Variable in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Deprecated. 
host - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
HOST - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
host - Variable in class org.apache.flume.source.SyslogUtils
 
hostname(String) - Method in class org.apache.flume.api.NettyAvroRpcClient.Builder
Hostname to connect to (required)

I

incrementAndGet(String) - Method in class org.apache.flume.CounterGroup
 
initialize() - Method in class org.apache.flume.channel.BasicChannelSemantics
Called upon first getTransaction() request, while synchronized on this Channel instance.
initialize(Context) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
initialize(Context) - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Initializes the channel provider.
initialValue() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionFactory
 
iprot_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
IRCSink - Class in org.apache.flume.sink.irc
 
IRCSink() - Constructor for class org.apache.flume.sink.irc.IRCSink
 
IRCSink.IRCConnectionListener - Class in org.apache.flume.sink.irc
 
IRCSink.IRCConnectionListener() - Constructor for class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
isActive() - Method in class org.apache.flume.api.NettyAvroRpcClient
 
isActive() - Method in interface org.apache.flume.api.RpcClient
Returns true if this object appears to be in a usable state, and it returns false if this object is permanently disabled.
isInitialized() - Method in class org.apache.flume.channel.file.FileChannel
 
isSet(ThriftFlumeEvent._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftFlumeEventServer.append_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated. Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftFlumeEventServer.close_args._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated. Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftFlumeEventServer.close_result._Fields) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated. Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field body is set (has been assigned a value) and false otherwise
isSetEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated. Returns true if field evt is set (has been assigned a value) and false otherwise
isSetFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field fields is set (has been assigned a value) and false otherwise
isSetHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field host is set (has been assigned a value) and false otherwise
isSetNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field nanos is set (has been assigned a value) and false otherwise
isSetPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field priority is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Returns true if field timestamp is set (has been assigned a value) and false otherwise

J

JdbcChannel - Class in org.apache.flume.channel.jdbc
A JDBC based channel implementation.
JdbcChannel() - Constructor for class org.apache.flume.channel.jdbc.JdbcChannel
Instantiates a new JDBC Channel.
JdbcChannelException - Exception in org.apache.flume.channel.jdbc
 
JdbcChannelException(String) - Constructor for exception org.apache.flume.channel.jdbc.JdbcChannelException
 
JdbcChannelException(String, Exception) - Constructor for exception org.apache.flume.channel.jdbc.JdbcChannelException
 
JdbcChannelException(Exception) - Constructor for exception org.apache.flume.channel.jdbc.JdbcChannelException
 
JdbcChannelProvider - Interface in org.apache.flume.channel.jdbc
Service provider interface for JDBC channel providers.
JdbcChannelProviderFactory - Class in org.apache.flume.channel.jdbc
 
JdbcChannelProviderImpl - Class in org.apache.flume.channel.jdbc.impl
 
JdbcChannelProviderImpl() - Constructor for class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
JdbcTransactionFactory - Class in org.apache.flume.channel.jdbc.impl
 
JdbcTransactionFactory(DataSource) - Constructor for class org.apache.flume.channel.jdbc.impl.JdbcTransactionFactory
 
JdbcTransactionImpl - Class in org.apache.flume.channel.jdbc.impl
 
JdbcTransactionImpl(DataSource, JdbcTransactionFactory) - Constructor for class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 

L

lastSeen - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
lastSeenState - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
LifecycleAware - Interface in org.apache.flume.lifecycle
An interface implemented by any class that has a defined, stateful, lifecycle.
lifecycleAware - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
LifecycleController - Class in org.apache.flume.lifecycle
 
LifecycleController() - Constructor for class org.apache.flume.lifecycle.LifecycleController
 
LifecycleException - Exception in org.apache.flume.lifecycle
 
LifecycleException() - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleException(String) - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleException(String, Throwable) - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleException(Throwable) - Constructor for exception org.apache.flume.lifecycle.LifecycleException
 
LifecycleState - Enum in org.apache.flume.lifecycle
 
LifecycleSupervisor - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor
 
LifecycleSupervisor.MonitorRunnable - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.MonitorRunnable() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
LifecycleSupervisor.Status - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.Status() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
LifecycleSupervisor.SupervisorPolicy - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.SupervisorPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy
 
LifecycleSupervisor.SupervisorPolicy.AlwaysRestartPolicy - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.SupervisorPolicy.AlwaysRestartPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy.AlwaysRestartPolicy
 
LifecycleSupervisor.SupervisorPolicy.OnceOnlyPolicy - Class in org.apache.flume.lifecycle
 
LifecycleSupervisor.SupervisorPolicy.OnceOnlyPolicy() - Constructor for class org.apache.flume.lifecycle.LifecycleSupervisor.SupervisorPolicy.OnceOnlyPolicy
 
load() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
load() - Method in class org.apache.flume.conf.properties.PropertiesFileConfigurationProvider
 
Log4jAppender - Class in org.apache.flume.clients.log4jappender
Appends Log4j Events to an external Flume client which is decribed by the Log4j configuration file.
Log4jAppender() - Constructor for class org.apache.flume.clients.log4jappender.Log4jAppender
If this constructor is used programmatically rather than from a log4j conf you must set the port and hostname and then call activateOptions() before calling append().
Log4jAppender(String, int) - Constructor for class org.apache.flume.clients.log4jappender.Log4jAppender
Sets the hostname and port.
Log4jAvroHeaders - Enum in org.apache.flume.clients.log4jappender
 
LoggerSink - Class in org.apache.flume.sink
A Sink implementation that logs all events received at the INFO level to the org.apache.flume.sink.LoggerSink logger.
LoggerSink() - Constructor for class org.apache.flume.sink.LoggerSink
 

M

main(String[]) - Static method in class org.apache.flume.client.avro.AvroCLIClient
 
main(String[]) - Static method in class org.apache.flume.node.Application
 
MemoryChannel - Class in org.apache.flume.channel
 
MemoryChannel() - Constructor for class org.apache.flume.channel.MemoryChannel
 
MemoryChannel.MemoryTransaction - Class in org.apache.flume.channel
 
MemoryChannel.MemoryTransaction(int) - Constructor for class org.apache.flume.channel.MemoryChannel.MemoryTransaction
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class org.apache.flume.source.SyslogUDPSource.syslogHandler
 
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
metaDataMap - Static variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
monitorService - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
MultiplexingChannelSelector - Class in org.apache.flume.channel
 
MultiplexingChannelSelector() - Constructor for class org.apache.flume.channel.MultiplexingChannelSelector
 
MySQLSchemaHandler - Class in org.apache.flume.channel.jdbc.impl
 
MySQLSchemaHandler(DataSource) - Constructor for class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 

N

NamedComponent - Interface in org.apache.flume
Enables a component to be tagged with a name so that it can be referred to uniquely within the configuration system.
nanos - Variable in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Deprecated. 
nanos - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
NANOS - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
NetcatSource - Class in org.apache.flume.source
A netcat-like source that listens on a given port and turns each line of text into an event.
NetcatSource() - Constructor for class org.apache.flume.source.NetcatSource
 
NetcatSource.AcceptHandler - Class in org.apache.flume.source
 
NetcatSource.AcceptHandler() - Constructor for class org.apache.flume.source.NetcatSource.AcceptHandler
 
NetcatSource.NetcatSocketHandler - Class in org.apache.flume.source
 
NetcatSource.NetcatSocketHandler() - Constructor for class org.apache.flume.source.NetcatSource.NetcatSocketHandler
 
NettyAvroRpcClient - Class in org.apache.flume.api
Avro/Netty implementation of RpcClient.
NettyAvroRpcClient.Builder - Class in org.apache.flume.api
Builder class used to construct NettyAvroRpcClient objects.
NettyAvroRpcClient.Builder() - Constructor for class org.apache.flume.api.NettyAvroRpcClient.Builder
 
nettyChannel - Variable in class org.apache.flume.source.SyslogUtils
 
newBuilder() - Static method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Creates a new AvroFlumeOGEvent RecordBuilder
newBuilder(AvroFlumeOGEvent.Builder) - Static method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Creates a new AvroFlumeOGEvent RecordBuilder by copying an existing Builder
newBuilder(AvroFlumeOGEvent) - Static method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Creates a new AvroFlumeOGEvent RecordBuilder by copying an existing AvroFlumeOGEvent instance
newBuilder() - Static method in class org.apache.flume.source.avro.AvroFlumeEvent
Creates a new AvroFlumeEvent RecordBuilder
newBuilder(AvroFlumeEvent.Builder) - Static method in class org.apache.flume.source.avro.AvroFlumeEvent
Creates a new AvroFlumeEvent RecordBuilder by copying an existing Builder
newBuilder(AvroFlumeEvent) - Static method in class org.apache.flume.source.avro.AvroFlumeEvent
Creates a new AvroFlumeEvent RecordBuilder by copying an existing AvroFlumeEvent instance
nextFile() - Method in class org.apache.flume.formatter.output.PathManager
 
NodeConfiguration - Interface in org.apache.flume.node
 
NodeConfigurationAware - Interface in org.apache.flume.node.nodemanager
 
NodeManager - Interface in org.apache.flume.node
 
NullSink - Class in org.apache.flume.sink
A Sink implementation that simply discards all events it receives.
NullSink() - Constructor for class org.apache.flume.sink.NullSink
 

O

OG_EVENT - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
onDisconnected() - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onError(String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onError(int, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onInvite(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onJoin(String, IRCUser) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onKick(String, IRCUser, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onMode(IRCUser, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onMode(String, IRCUser, IRCModeParser) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onNick(IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onNodeConfigurationChanged(NodeConfiguration) - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
onNodeConfigurationChanged(NodeConfiguration) - Method in interface org.apache.flume.node.nodemanager.NodeConfigurationAware
 
onNotice(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onPart(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onPing(String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onPrivmsg(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onQuit(IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onRegistered() - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onReply(int, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
onTopic(String, IRCUser, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
open() - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
open(String, HDFSWriter, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
open(String, CompressionCodec, CompressionType, HDFSWriter, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
open(String, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
open(String, CompressionCodec, CompressionType, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
open(String, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
open(String, CompressionCodec, CompressionType, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
open(String, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
open(String, CompressionCodec, CompressionType, FlumeFormatter) - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
open(String, FlumeFormatter) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
open(String, CompressionCodec, CompressionType, FlumeFormatter) - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
oprot_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
org.apache.flume - package org.apache.flume
 
org.apache.flume.api - package org.apache.flume.api
 
org.apache.flume.channel - package org.apache.flume.channel
 
org.apache.flume.channel.file - package org.apache.flume.channel.file
 
org.apache.flume.channel.jdbc - package org.apache.flume.channel.jdbc
 
org.apache.flume.channel.jdbc.impl - package org.apache.flume.channel.jdbc.impl
 
org.apache.flume.client.avro - package org.apache.flume.client.avro
 
org.apache.flume.clients.log4jappender - package org.apache.flume.clients.log4jappender
 
org.apache.flume.conf - package org.apache.flume.conf
 
org.apache.flume.conf.file - package org.apache.flume.conf.file
 
org.apache.flume.conf.properties - package org.apache.flume.conf.properties
 
org.apache.flume.event - package org.apache.flume.event
 
org.apache.flume.formatter.output - package org.apache.flume.formatter.output
 
org.apache.flume.lifecycle - package org.apache.flume.lifecycle
 
org.apache.flume.node - package org.apache.flume.node
 
org.apache.flume.node.nodemanager - package org.apache.flume.node.nodemanager
 
org.apache.flume.sink - package org.apache.flume.sink
 
org.apache.flume.sink.hdfs - package org.apache.flume.sink.hdfs
 
org.apache.flume.sink.irc - package org.apache.flume.sink.irc
 
org.apache.flume.source - package org.apache.flume.source
 
org.apache.flume.source.avro - package org.apache.flume.source.avro
 
org.apache.flume.source.avroLegacy - package org.apache.flume.source.avroLegacy
 
org.apache.flume.source.thriftLegacy - package org.apache.flume.source.thriftLegacy
 

P

parseOptions() - Method in class org.apache.flume.node.Application
 
PathManager - Class in org.apache.flume.formatter.output
 
PathManager() - Constructor for class org.apache.flume.formatter.output.PathManager
 
PAYLOAD_LENGTH_THRESHOLD - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
The length for payload bytes that will be stored inline.
PersistableEvent - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent(String, Event) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
PersistableEvent.Builder - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent.Builder(String, long) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
PersistableEvent.HeaderEntry - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent.HeaderEntry(String, String) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
PersistableEvent.SpillableString - Class in org.apache.flume.channel.jdbc.impl
 
PersistableEvent.SpillableString(String, int) - Constructor for class org.apache.flume.channel.jdbc.impl.PersistableEvent.SpillableString
 
persistEvent(String, Event) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
persistEvent(String, Event) - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Writes the event to the persistent store.
PollableSource - Interface in org.apache.flume
A Source that requires an external driver to poll to determine whether there are events that are available to ingest from the source.
PollableSource.Status - Enum in org.apache.flume
 
PollableSourceRunner - Class in org.apache.flume.source
An implementation of SourceRunner that can drive a PollableSource.
PollableSourceRunner() - Constructor for class org.apache.flume.source.PollableSourceRunner
 
PollableSourceRunner.PollingRunner - Class in org.apache.flume.source
 
PollableSourceRunner.PollingRunner() - Constructor for class org.apache.flume.source.PollableSourceRunner.PollingRunner
 
port(Integer) - Method in class org.apache.flume.api.NettyAvroRpcClient.Builder
Port to connect to (required)
port - Variable in class org.apache.flume.source.SyslogUtils
 
PREFIX - Static variable in class org.apache.flume.channel.jdbc.ConfigurationConstants
 
priority - Variable in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Deprecated. 
Priority - Enum in com.cloudera.flume.handlers.avro
 
Priority - Enum in com.cloudera.flume.handlers.thrift
 
priority - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
PRIORITY - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
process(org.apache.thrift.protocol.TProtocol, org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
Deprecated.  
process(int, org.apache.thrift.protocol.TProtocol, org.apache.thrift.protocol.TProtocol) - Method in interface com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor.ProcessFunction
Deprecated.  
process() - Method in interface org.apache.flume.PollableSource
 
process() - Method in class org.apache.flume.sink.AvroSink
 
process() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
process() - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
process() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
Pull events out of channel and send it to HDFS - take at the most txnEventMax, that's the maximum #events to hold in channel for a given transaction - find the corresponding bucket for the event, ensure the file is open - extract the pay-load and append to HDFS file
process() - Method in class org.apache.flume.sink.irc.IRCSink
 
process() - Method in class org.apache.flume.sink.LoggerSink
 
process() - Method in class org.apache.flume.sink.NullSink
 
process() - Method in interface org.apache.flume.Sink
Requests the sink to attempt to consume data from attached channel
process() - Method in class org.apache.flume.sink.RollingFileSink
 
process() - Method in interface org.apache.flume.SinkProcessor
Handle a request to poll the owned sinks.
process() - Method in class org.apache.flume.source.SequenceGeneratorSource
 
processEvent(Event) - Method in class org.apache.flume.channel.ChannelProcessor
Attempts to put the given event into each configured channel.
processEventBatch(List<Event>) - Method in class org.apache.flume.channel.ChannelProcessor
Attempts to put the given events into each configured channel.
processMap_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
Deprecated.  
PropertiesFileConfigurationProvider - Class in org.apache.flume.conf.properties
A configuration provider that uses properties file for specifying configuration.
PropertiesFileConfigurationProvider() - Constructor for class org.apache.flume.conf.properties.PropertiesFileConfigurationProvider
 
PROTOCOL - Static variable in interface com.cloudera.flume.handlers.avro.FlumeOGEventAvroServer.Callback
 
PROTOCOL - Static variable in interface com.cloudera.flume.handlers.avro.FlumeOGEventAvroServer
 
PROTOCOL - Static variable in interface org.apache.flume.source.avro.AvroSourceProtocol.Callback
 
PROTOCOL - Static variable in interface org.apache.flume.source.avro.AvroSourceProtocol
 
PseudoTxnMemoryChannel - Class in org.apache.flume.channel
A capacity-capped Channel implementation that supports in-memory buffering and delivery of events.
PseudoTxnMemoryChannel() - Constructor for class org.apache.flume.channel.PseudoTxnMemoryChannel
 
PseudoTxnMemoryChannel.NoOpTransaction - Class in org.apache.flume.channel
A no-op transaction implementation that does nothing at all.
PseudoTxnMemoryChannel.NoOpTransaction() - Constructor for class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
put(int, Object) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
 
put(Event) - Method in class org.apache.flume.channel.BasicChannelSemantics
Ensures that a transaction exists for this thread and then delegates the put to the thread's BasicTransactionSemantics instance.
put(Event) - Method in class org.apache.flume.channel.BasicTransactionSemantics
The method to which BasicChannelSemantics delegates calls to put.
put(Channel, Event) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for single-event put transactions.
put(Channel, Collection<Event>) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for multiple-event put transactions.
put(Event) - Method in class org.apache.flume.channel.file.FileChannel
 
put(Event) - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
put(Event) - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
put(Event) - Method in interface org.apache.flume.Channel
Puts the given event into the channel.
put(String, String) - Method in class org.apache.flume.Context
Associates the specified value with the specified key in this context.
put(int, Object) - Method in class org.apache.flume.source.avro.AvroFlumeEvent
 
putAll(Map<String, String>) - Method in class org.apache.flume.Context
Associates all of the given map's keys and values in the Context.
putToFields(String, ByteBuffer) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  

Q

QUERY_CHANNEL_SIZE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLE_CHANNEL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLH_EVENT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLN_HEADER - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLP_EVENT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_INDEX_FLV_HEADER - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_SCHEMA_FLUME - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_EVENT - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_HEADER - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_NMSPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_PLSPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
QUERY_CREATE_TABLE_FL_VLSPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 

R

read(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
read(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
read(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
read(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
recv_close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
releaseProvider(String) - Static method in class org.apache.flume.channel.jdbc.JdbcChannelProviderFactory
 
remove(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
remove(LifecycleAware) - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
remove(LifecycleAware) - Method in interface org.apache.flume.node.NodeManager
 
removeEvent(String) - Method in class org.apache.flume.channel.jdbc.impl.JdbcChannelProviderImpl
 
removeEvent(String) - Method in interface org.apache.flume.channel.jdbc.JdbcChannelProvider
Removes the next event for the named channel from the underlying persistent store.
replaceShorthand(char, Map<String, String>) - Static method in class org.apache.flume.formatter.output.BucketPath
Hardcoded lookups for %x style escape replacement.
ReplicatingChannelSelector - Class in org.apache.flume.channel
Replicating channel selector.
ReplicatingChannelSelector() - Constructor for class org.apache.flume.channel.ReplicatingChannelSelector
 
requiresLayout() - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
 
rollback() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
rollback() - Method in class org.apache.flume.channel.file.FileChannel.FileBackedTransaction
 
rollback() - Method in class org.apache.flume.channel.jdbc.impl.JdbcTransactionImpl
 
rollback() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
rollback() - Method in interface org.apache.flume.Transaction
Indicates that the transaction can must be aborted.
RollingFileSink - Class in org.apache.flume.sink
 
RollingFileSink() - Constructor for class org.apache.flume.sink.RollingFileSink
 
rotate() - Method in class org.apache.flume.formatter.output.PathManager
 
RpcClient - Interface in org.apache.flume.api
Public client interface for sending data to Flume.
RpcClientFactory - Class in org.apache.flume.api
Factory class to construct Flume RPCClient implementations.
RpcClientFactory() - Constructor for class org.apache.flume.api.RpcClientFactory
 
run() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider.FileWatcherRunnable
 
run() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
run() - Method in class org.apache.flume.node.Application
 
run() - Method in class org.apache.flume.SinkRunner.PollingRunner
 
run() - Method in class org.apache.flume.source.NetcatSource.AcceptHandler
 
run() - Method in class org.apache.flume.source.NetcatSource.NetcatSocketHandler
 
run() - Method in class org.apache.flume.source.PollableSourceRunner.PollingRunner
 
run() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource.ThriftHandler
 

S

SCHEMA$ - Static variable in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
 
SCHEMA$ - Static variable in enum com.cloudera.flume.handlers.avro.Priority
 
SCHEMA$ - Static variable in class org.apache.flume.source.avro.AvroFlumeEvent
 
SCHEMA$ - Static variable in enum org.apache.flume.source.avro.Status
 
schemaExists() - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
schemaExists() - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
schemaExists() - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
 
SchemaHandler - Interface in org.apache.flume.channel.jdbc.impl
A handler for creating and validating database schema for use by the JDBC channel implementation.
SchemaHandlerFactory - Class in org.apache.flume.channel.jdbc.impl
A factory for SchemaHandlers.
send_append(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
send_close() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
seqid_ - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
SequenceGeneratorSource - Class in org.apache.flume.source
 
SequenceGeneratorSource() - Constructor for class org.apache.flume.source.SequenceGeneratorSource
 
set(String, Long) - Method in class org.apache.flume.CounterGroup
 
setArgs(String[]) - Method in class org.apache.flume.node.Application
 
setBaseDirectory(File) - Method in class org.apache.flume.formatter.output.PathManager
 
setBasePayload(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setBody(ByteBuffer) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Sets the value of the 'body' field
setBody(ByteBuffer) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Sets the value of the 'body' field.
setBody(byte[]) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setBody(ByteBuffer) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setBody(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
setBody(byte[]) - Method in interface org.apache.flume.Event
Sets the raw byte array of the data contained in this event.
setBody(byte[]) - Method in class org.apache.flume.event.SimpleEvent
 
setBody(ByteBuffer) - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Sets the value of the 'body' field
setBody(ByteBuffer) - Method in class org.apache.flume.source.avro.AvroFlumeEvent
Sets the value of the 'body' field.
setBodyIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setChannel(String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setChannel(Channel) - Method in class org.apache.flume.sink.AbstractSink
 
setChannel(Channel) - Method in interface org.apache.flume.Sink
Sets the channel the sink will consume from
setChannelFactory(ChannelFactory) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setChannelProcessor(ChannelProcessor) - Method in class org.apache.flume.source.AbstractSource
 
setChannelProcessor(ChannelProcessor) - Method in interface org.apache.flume.Source
Specifies which channel processor will handle this source's events.
setChannels(List<Channel>) - Method in class org.apache.flume.channel.AbstractChannelSelector
 
setChannels(List<Channel>) - Method in interface org.apache.flume.ChannelSelector
 
setChannels(Map<String, Channel>) - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
setConfigurationAware(NodeConfigurationAware) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setConfigurationProvider(ConfigurationProvider) - Method in class org.apache.flume.node.FlumeNode
 
setCounters(HashMap<String, AtomicLong>) - Method in class org.apache.flume.CounterGroup
 
setDesiredState(LifecycleAware, LifecycleState) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
setDirectory(File) - Method in class org.apache.flume.channel.file.FileChannel
 
setDirectory(File) - Method in class org.apache.flume.sink.RollingFileSink
 
setEventId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setEventId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
setEvt(ThriftFlumeEvent) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
setEvtIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
setFields(Map<CharSequence, ByteBuffer>) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Sets the value of the 'fields' field
setFields(Map<CharSequence, ByteBuffer>) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Sets the value of the 'fields' field.
setFields(Map<String, ByteBuffer>) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setFieldsIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setFieldValue(ThriftFlumeEvent._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setFieldValue(ThriftFlumeEventServer.append_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
setFieldValue(ThriftFlumeEventServer.close_args._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
setFieldValue(ThriftFlumeEventServer.close_result._Fields, Object) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
setFile(File) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setFormatter(EventFormatter) - Method in class org.apache.flume.sink.RollingFileSink
 
setHeader(long, String, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setHeaderNameSpill(long, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setHeaders(Map<String, String>) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent
 
setHeaders(Map<String, String>) - Method in interface org.apache.flume.Event
Set the event headers
setHeaders(Map<String, String>) - Method in class org.apache.flume.event.SimpleEvent
 
setHeaders(Map<CharSequence, CharSequence>) - Method in class org.apache.flume.source.avro.AvroFlumeEvent.Builder
Sets the value of the 'headers' field
setHeaders(Map<CharSequence, CharSequence>) - Method in class org.apache.flume.source.avro.AvroFlumeEvent
Sets the value of the 'headers' field.
setHeaderValueSpill(long, String) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setHost(CharSequence) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Sets the value of the 'host' field
setHost(CharSequence) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Sets the value of the 'host' field.
setHost(String) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setHostIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setHostname(String) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Set the first flume hop hostname.
setId(long) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.HeaderEntry
 
setName(String) - Method in class org.apache.flume.channel.AbstractChannel
 
setName(String) - Method in class org.apache.flume.channel.AbstractChannelSelector
 
setName(String) - Method in class org.apache.flume.CounterGroup
 
setName(String) - Method in interface org.apache.flume.NamedComponent
 
setName(String) - Method in class org.apache.flume.node.FlumeNode
 
setName(String) - Method in class org.apache.flume.sink.AbstractSink
 
setName(String) - Method in class org.apache.flume.source.AbstractSource
 
setNanos(long) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Sets the value of the 'nanos' field
setNanos(Long) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Sets the value of the 'nanos' field.
setNanos(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setNanosIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setNodeManager(NodeManager) - Method in class org.apache.flume.node.FlumeNode
 
setNodeName(String) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setNodes(Set<LifecycleAware>) - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
setNodes(Set<LifecycleAware>) - Method in interface org.apache.flume.node.NodeManager
 
setPort(int) - Method in class org.apache.flume.clients.log4jappender.Log4jAppender
Set the port on the hostname to connect to.
setPriority(Priority) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Sets the value of the 'priority' field
setPriority(Priority) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Sets the value of the 'priority' field.
setPriority(Priority) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setPriorityIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setRollInterval(long) - Method in class org.apache.flume.sink.RollingFileSink
 
setSink(SinkProcessor) - Method in class org.apache.flume.SinkRunner
 
setSinkFactory(SinkFactory) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setSinkRunners(Map<String, SinkRunner>) - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
setSinks(List<Sink>) - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
setSinks(List<Sink>) - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
setSinks(List<Sink>) - Method in interface org.apache.flume.SinkProcessor
Set all sinks to work with.
setSource(Source) - Method in class org.apache.flume.SourceRunner
 
setSourceFactory(SourceFactory) - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
setSourceRunners(Map<String, SourceRunner>) - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
setSpillPayload(byte[]) - Method in class org.apache.flume.channel.jdbc.impl.PersistableEvent.Builder
 
setTimestamp(long) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent.Builder
Sets the value of the 'timestamp' field
setTimestamp(Long) - Method in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
setTimestampIsSet(boolean) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
sharedInstance() - Static method in class org.apache.flume.channel.PseudoTxnMemoryChannel.NoOpTransaction
 
shouldRotate() - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
SimpleEvent - Class in org.apache.flume.event
 
SimpleEvent() - Constructor for class org.apache.flume.event.SimpleEvent
 
SimpleNodeConfiguration - Class in org.apache.flume.conf.file
 
SimpleNodeConfiguration() - Constructor for class org.apache.flume.conf.file.SimpleNodeConfiguration
 
Sink - Interface in org.apache.flume
A sink is connected to a Channel and consumes its contents, sending them to a configured destination that may vary according to the sink type.
Sink.Status - Enum in org.apache.flume
 
SinkFactory - Interface in org.apache.flume
 
SinkGroup - Class in org.apache.flume.sink
Configuration concept for handling multiple sinks working together.
SinkGroup(List<Sink>) - Constructor for class org.apache.flume.sink.SinkGroup
 
SinkProcessor - Interface in org.apache.flume
Interface for a device that allows abstraction of the behavior of multiple sinks, always assigned to a SinkRunner
SinkProcessorFactory - Class in org.apache.flume.sink
 
SinkProcessorFactory() - Constructor for class org.apache.flume.sink.SinkProcessorFactory
 
SinkProcessorType - Enum in org.apache.flume
 
SinkRunner - Class in org.apache.flume
A driver for sinks that polls them, attempting to process events if any are available in the Channel.
SinkRunner() - Constructor for class org.apache.flume.SinkRunner
 
SinkRunner(SinkProcessor) - Constructor for class org.apache.flume.SinkRunner
 
SinkRunner.PollingRunner - Class in org.apache.flume
Runnable that polls a SinkProcessor and manages event delivery notification, BACKOFF delay handling, etc.
SinkRunner.PollingRunner() - Constructor for class org.apache.flume.SinkRunner.PollingRunner
 
SinkType - Enum in org.apache.flume.sink
Enumeration of built in sink types available in the system.
Source - Interface in org.apache.flume
A source generates and calls methods on the configured ChannelProcessor to persist those events into the configured channels.
SourceFactory - Interface in org.apache.flume
 
SourceRunner - Class in org.apache.flume
A source runner controls how a source is driven.
SourceRunner() - Constructor for class org.apache.flume.SourceRunner
 
SourceType - Enum in org.apache.flume.source
Enumeration of built in source types available in the system.
start() - Method in class org.apache.flume.channel.AbstractChannel
 
start() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
start() - Method in interface org.apache.flume.lifecycle.LifecycleAware
Starts a service or component.
start() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
start() - Method in class org.apache.flume.node.FlumeNode
 
start() - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
start() - Method in class org.apache.flume.sink.AbstractSink
 
start() - Method in class org.apache.flume.sink.AvroSink
 
start() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
start() - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
start() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
 
start() - Method in class org.apache.flume.sink.irc.IRCSink
 
start() - Method in class org.apache.flume.sink.NullSink
 
start() - Method in class org.apache.flume.sink.RollingFileSink
 
start() - Method in class org.apache.flume.SinkRunner
 
start() - Method in class org.apache.flume.source.AbstractSource
 
start() - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
start() - Method in class org.apache.flume.source.AvroSource
 
start() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
start() - Method in class org.apache.flume.source.ExecSource
 
start() - Method in class org.apache.flume.source.NetcatSource
 
start() - Method in class org.apache.flume.source.PollableSourceRunner
 
start() - Method in class org.apache.flume.source.SequenceGeneratorSource
 
start() - Method in class org.apache.flume.source.SyslogTcpSource
 
start() - Method in class org.apache.flume.source.SyslogUDPSource
 
start() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
START_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
 
Status - Enum in org.apache.flume.source.avro
 
STMT_DELETE_EVENT_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_EVENT_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_DELETE_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_PAYLOAD_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_FETCH_PAYLOAD_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_EVENT_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_EVENT_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_HEADER_BASE - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_HEADER_NAME_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
STMT_INSERT_HEADER_VALUE_SPILL - Static variable in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
stop() - Method in class org.apache.flume.channel.AbstractChannel
 
stop() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
stop() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
stop() - Method in interface org.apache.flume.lifecycle.LifecycleAware
Stops a service or component.
stop() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
stop() - Method in class org.apache.flume.node.FlumeNode
 
stop() - Method in class org.apache.flume.node.nodemanager.DefaultLogicalNodeManager
 
stop() - Method in class org.apache.flume.sink.AbstractSink
 
stop() - Method in class org.apache.flume.sink.AvroSink
 
stop() - Method in class org.apache.flume.sink.DefaultSinkProcessor
 
stop() - Method in class org.apache.flume.sink.FailoverSinkProcessor
 
stop() - Method in class org.apache.flume.sink.hdfs.HDFSEventSink
 
stop() - Method in class org.apache.flume.sink.irc.IRCSink
 
stop() - Method in class org.apache.flume.sink.NullSink
 
stop() - Method in class org.apache.flume.sink.RollingFileSink
 
stop() - Method in class org.apache.flume.SinkRunner
 
stop() - Method in class org.apache.flume.source.AbstractSource
 
stop() - Method in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
stop() - Method in class org.apache.flume.source.AvroSource
 
stop() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
stop() - Method in class org.apache.flume.source.ExecSource
 
stop() - Method in class org.apache.flume.source.NetcatSource
 
stop() - Method in class org.apache.flume.source.PollableSourceRunner
 
stop() - Method in class org.apache.flume.source.SequenceGeneratorSource
 
stop() - Method in class org.apache.flume.source.SyslogTcpSource
 
stop() - Method in class org.apache.flume.source.SyslogUDPSource
 
stop() - Method in class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
STOP_OR_ERROR - Static variable in enum org.apache.flume.lifecycle.LifecycleState
 
stopAll(List<LifecycleAware>) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
storeEvent(PersistableEvent, Connection) - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
storeEvent(PersistableEvent, Connection) - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
storeEvent(PersistableEvent, Connection) - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Inserts the given persistent event into the database.
supervise(LifecycleAware, LifecycleSupervisor.SupervisorPolicy, LifecycleState) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 
supervisoree - Variable in class org.apache.flume.lifecycle.LifecycleSupervisor.MonitorRunnable
 
sync() - Method in class org.apache.flume.sink.hdfs.BucketWriter
 
sync() - Method in class org.apache.flume.sink.hdfs.HDFSCompressedDataStream
 
sync() - Method in class org.apache.flume.sink.hdfs.HDFSDataStream
 
sync() - Method in class org.apache.flume.sink.hdfs.HDFSSequenceFile
 
sync() - Method in interface org.apache.flume.sink.hdfs.HDFSWriter
 
SYSLOG_FACILITY - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_SEVERITY - Static variable in class org.apache.flume.source.SyslogUtils
 
SYSLOG_TCP_PORT - Static variable in class org.apache.flume.source.SyslogTcpSource
 
SYSLOG_UDP_PORT - Static variable in class org.apache.flume.source.SyslogUDPSource
 
SyslogTcpSource - Class in org.apache.flume.source
 
SyslogTcpSource() - Constructor for class org.apache.flume.source.SyslogTcpSource
 
SyslogTcpSource.syslogTcpHandler - Class in org.apache.flume.source
 
SyslogTcpSource.syslogTcpHandler() - Constructor for class org.apache.flume.source.SyslogTcpSource.syslogTcpHandler
 
SyslogUDPSource - Class in org.apache.flume.source
 
SyslogUDPSource() - Constructor for class org.apache.flume.source.SyslogUDPSource
 
SyslogUDPSource.syslogHandler - Class in org.apache.flume.source
 
SyslogUDPSource.syslogHandler() - Constructor for class org.apache.flume.source.SyslogUDPSource.syslogHandler
 
SyslogUtils - Class in org.apache.flume.source
 
SyslogUtils() - Constructor for class org.apache.flume.source.SyslogUtils
 
SYSPROP_CALLED_FROM_SERVICE - Static variable in class org.apache.flume.Constants
 

T

TAG_REGEX - Static variable in class org.apache.flume.formatter.output.BucketPath
These are useful to other classes which might want to search for tags in strings.
tagPattern - Static variable in class org.apache.flume.formatter.output.BucketPath
 
take() - Method in class org.apache.flume.channel.BasicChannelSemantics
Ensures that a transaction exists for this thread and then delegates the take to the thread's BasicTransactionSemantics instance.
take() - Method in class org.apache.flume.channel.BasicTransactionSemantics
The method to which BasicChannelSemantics delegates calls to take.
take(Channel) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for single-event take transactions.
take(Channel, int) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for multiple-event take transactions.
take() - Method in class org.apache.flume.channel.file.FileChannel
 
take() - Method in class org.apache.flume.channel.jdbc.JdbcChannel
 
take() - Method in class org.apache.flume.channel.PseudoTxnMemoryChannel
 
take() - Method in interface org.apache.flume.Channel
Returns the next event from the channel if available.
TextDelimitedOutputFormatter - Class in org.apache.flume.formatter.output
 
TextDelimitedOutputFormatter() - Constructor for class org.apache.flume.formatter.output.TextDelimitedOutputFormatter
 
ThriftFlumeEvent - Class in com.cloudera.flume.handlers.thrift
Deprecated. 
ThriftFlumeEvent() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
ThriftFlumeEvent(long, Priority, ByteBuffer, long, String, Map<String, ByteBuffer>) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
ThriftFlumeEvent(ThriftFlumeEvent) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated. Performs a deep copy on other.
ThriftFlumeEvent._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer - Class in com.cloudera.flume.handlers.thrift
Deprecated. 
ThriftFlumeEventServer() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer
Deprecated.  
ThriftFlumeEventServer.append_args - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.append_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
ThriftFlumeEventServer.append_args(ThriftFlumeEvent) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
ThriftFlumeEventServer.append_args(ThriftFlumeEventServer.append_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated. Performs a deep copy on other.
ThriftFlumeEventServer.append_args._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer.AsyncClient - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.AsyncClient(org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.async.TAsyncClientManager, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient
Deprecated.  
ThriftFlumeEventServer.AsyncClient.append_call - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.AsyncClient.append_call(ThriftFlumeEvent, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
Deprecated.  
ThriftFlumeEventServer.AsyncClient.close_call - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.AsyncClient.close_call(<any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
Deprecated.  
ThriftFlumeEventServer.AsyncClient.Factory - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.AsyncClient.Factory(org.apache.thrift.async.TAsyncClientManager, org.apache.thrift.protocol.TProtocolFactory) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.Factory
Deprecated.  
ThriftFlumeEventServer.AsyncIface - Interface in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Client - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Client(org.apache.thrift.protocol.TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
ThriftFlumeEventServer.Client(org.apache.thrift.protocol.TProtocol, org.apache.thrift.protocol.TProtocol) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client
Deprecated.  
ThriftFlumeEventServer.Client.Factory - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Client.Factory() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Client.Factory
Deprecated.  
ThriftFlumeEventServer.close_args - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.close_args() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
ThriftFlumeEventServer.close_args(ThriftFlumeEventServer.close_args) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated. Performs a deep copy on other.
ThriftFlumeEventServer.close_args._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer.close_result - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.close_result() - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
ThriftFlumeEventServer.close_result(ThriftFlumeEventServer.close_result) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated. Performs a deep copy on other.
ThriftFlumeEventServer.close_result._Fields - Enum in com.cloudera.flume.handlers.thrift
Deprecated. The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftFlumeEventServer.Iface - Interface in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Processor - Class in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftFlumeEventServer.Processor(ThriftFlumeEventServer.Iface) - Constructor for class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.Processor
Deprecated.  
ThriftFlumeEventServer.Processor.ProcessFunction - Interface in com.cloudera.flume.handlers.thrift
Deprecated.  
ThriftLegacySource - Class in org.apache.flume.source.thriftLegacy
 
ThriftLegacySource() - Constructor for class org.apache.flume.source.thriftLegacy.ThriftLegacySource
 
ThriftLegacySource.ThriftHandler - Class in org.apache.flume.source.thriftLegacy
 
ThriftLegacySource.ThriftHandler(TServer) - Constructor for class org.apache.flume.source.thriftLegacy.ThriftLegacySource.ThriftHandler
 
timestamp - Variable in class com.cloudera.flume.handlers.avro.AvroFlumeOGEvent
Deprecated. 
timestamp - Variable in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
TIMESTAMP - Static variable in class org.apache.flume.source.avroLegacy.AvroLegacySource
 
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
toString() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
toString() - Method in class org.apache.flume.channel.BasicTransactionSemantics
 
toString() - Method in class org.apache.flume.channel.file.FileChannel.FileBackedTransaction
 
toString() - Method in enum org.apache.flume.channel.jdbc.DatabaseType
 
toString() - Method in enum org.apache.flume.channel.jdbc.TransactionIsolation
 
toString() - Method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
 
toString() - Method in class org.apache.flume.conf.file.AbstractFileConfigurationProvider
 
toString() - Method in class org.apache.flume.conf.file.SimpleNodeConfiguration
 
toString() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.AgentConfiguration
 
toString() - Method in class org.apache.flume.conf.properties.FlumeConfiguration.ComponentConfiguration
 
toString() - Method in class org.apache.flume.Context
 
toString() - Method in class org.apache.flume.CounterGroup
 
toString() - Method in class org.apache.flume.event.SimpleEvent
 
toString() - Method in class org.apache.flume.lifecycle.LifecycleSupervisor.Status
 
toString() - Method in class org.apache.flume.node.FlumeNode
 
toString() - Method in class org.apache.flume.node.nodemanager.AbstractLogicalNodeManager
 
toString() - Method in class org.apache.flume.SinkRunner
 
toString() - Method in class org.apache.flume.source.AvroSource
 
toString() - Method in class org.apache.flume.source.EventDrivenSourceRunner
 
toString() - Method in class org.apache.flume.source.PollableSourceRunner
 
transact(Channel, Runnable) - Static method in class org.apache.flume.channel.ChannelUtils
A convenience method for transactions that don't require a return value.
transact(Channel, Callable<T>) - Static method in class org.apache.flume.channel.ChannelUtils
A general optimistic implementation of Transaction client semantics.
Transaction - Interface in org.apache.flume
Provides the transaction boundary while accessing a channel.
Transaction.TransactionState - Enum in org.apache.flume
 
TransactionIsolation - Enum in org.apache.flume.channel.jdbc
 

U

unknown(String, String, String, String) - Method in class org.apache.flume.sink.irc.IRCSink.IRCConnectionListener
 
unregister(Channel) - Method in class org.apache.flume.channel.DefaultChannelFactory
 
unregister(Channel) - Method in interface org.apache.flume.ChannelFactory
 
unregister(Sink) - Method in class org.apache.flume.sink.DefaultSinkFactory
 
unregister(Sink) - Method in interface org.apache.flume.SinkFactory
 
unregister(Source) - Method in class org.apache.flume.source.DefaultSourceFactory
 
unregister(Source) - Method in interface org.apache.flume.SourceFactory
 
unsetBody() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetEvt() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
unsetFields() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetHost() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetNanos() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetPriority() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsetTimestamp() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
unsupervise(LifecycleAware) - Method in class org.apache.flume.lifecycle.LifecycleSupervisor
 

V

validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
validate() - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
validateSchema() - Method in class org.apache.flume.channel.jdbc.impl.DerbySchemaHandler
 
validateSchema() - Method in class org.apache.flume.channel.jdbc.impl.MySQLSchemaHandler
 
validateSchema() - Method in interface org.apache.flume.channel.jdbc.impl.SchemaHandler
Validates the schema.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.avro.Priority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.Priority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.BasicTransactionSemantics.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.ChannelSelectorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.ChannelType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.lifecycle.LifecycleState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.PollableSource.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.sink.hdfs.BucketWriter.BucketFlushStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.sink.SinkType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.Sink.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.SinkProcessorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.avro.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.source.SourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flume.Transaction.TransactionState
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.cloudera.flume.handlers.avro.Priority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.EventStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.Priority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEvent._Fields
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args._Fields
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args._Fields
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result._Fields
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.BasicTransactionSemantics.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.ChannelSelectorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.ChannelType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.jdbc.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.channel.jdbc.TransactionIsolation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.clients.log4jappender.Log4jAvroHeaders
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.lifecycle.LifecycleState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.PollableSource.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.sink.hdfs.BucketWriter.BucketFlushStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.sink.SinkType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.Sink.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.SinkProcessorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.avro.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.source.SourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flume.Transaction.TransactionState
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitForOneOf(LifecycleAware, LifecycleState[]) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
waitForOneOf(LifecycleAware, LifecycleState[], long) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
waitForState(LifecycleAware, LifecycleState) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
waitForState(LifecycleAware, LifecycleState, long) - Static method in class org.apache.flume.lifecycle.LifecycleController
 
withBody(byte[], Map<String, String>) - Static method in class org.apache.flume.event.EventBuilder
Instantiate an Event instance based on the provided body and headers.
withBody(byte[]) - Static method in class org.apache.flume.event.EventBuilder
 
withBody(String, Charset, Map<String, String>) - Static method in class org.apache.flume.event.EventBuilder
 
withBody(String, Charset) - Static method in class org.apache.flume.event.EventBuilder
 
write(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEvent
Deprecated.  
write(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.append_args
Deprecated.  
write(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_args
Deprecated.  
write(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.close_result
Deprecated.  
write_args(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.append_call
Deprecated.  
write_args(org.apache.thrift.protocol.TProtocol) - Method in class com.cloudera.flume.handlers.thrift.ThriftFlumeEventServer.AsyncClient.close_call
Deprecated.  

A B C D E F G H I J L M N O P Q R S T U V W

Copyright © 2009-2012 Apache Software Foundation. All Rights Reserved.