[PATCH] Unlinline a bunch of other functions

Remove the "inline" keyword from a bunch of big functions in the kernel with
the goal of shrinking it by 30kb to 40kb

Signed-off-by: Arjan van de Ven <arjan@infradead.org>
Signed-off-by: Ingo Molnar <mingo@elte.hu>
Acked-by: Jeff Garzik <jgarzik@pobox.com>
Signed-off-by: Andrew Morton <akpm@osdl.org>
Signed-off-by: Linus Torvalds <torvalds@osdl.org>
This commit is contained in:
Arjan van de Ven 2006-01-14 13:20:43 -08:00 committed by Linus Torvalds
parent b0a9499c3d
commit 858119e159
74 changed files with 226 additions and 227 deletions

View File

@ -153,7 +153,7 @@ static int acpi_ec_polling_mode = EC_POLLING;
Transaction Management Transaction Management
-------------------------------------------------------------------------- */ -------------------------------------------------------------------------- */
static inline u32 acpi_ec_read_status(union acpi_ec *ec) static u32 acpi_ec_read_status(union acpi_ec *ec)
{ {
u32 status = 0; u32 status = 0;

View File

@ -48,7 +48,7 @@ struct firmware_priv {
struct timer_list timeout; struct timer_list timeout;
}; };
static inline void static void
fw_load_abort(struct firmware_priv *fw_priv) fw_load_abort(struct firmware_priv *fw_priv)
{ {
set_bit(FW_STATUS_ABORT, &fw_priv->status); set_bit(FW_STATUS_ABORT, &fw_priv->status);

View File

@ -294,7 +294,7 @@ fail:
* This helper just factors out common code between do_lo_send_direct_write() * This helper just factors out common code between do_lo_send_direct_write()
* and do_lo_send_write(). * and do_lo_send_write().
*/ */
static inline int __do_lo_send_write(struct file *file, static int __do_lo_send_write(struct file *file,
u8 __user *buf, const int len, loff_t pos) u8 __user *buf, const int len, loff_t pos)
{ {
ssize_t bw; ssize_t bw;

View File

@ -494,7 +494,7 @@ static inline void bcsp_unslip_one_byte(struct bcsp_struct *bcsp, unsigned char
} }
} }
static inline void bcsp_complete_rx_pkt(struct hci_uart *hu) static void bcsp_complete_rx_pkt(struct hci_uart *hu)
{ {
struct bcsp_struct *bcsp = hu->priv; struct bcsp_struct *bcsp = hu->priv;
int pass_up; int pass_up;

View File

@ -220,7 +220,7 @@ static __inline__ void r128_emit_tex1(drm_r128_private_t * dev_priv)
ADVANCE_RING(); ADVANCE_RING();
} }
static __inline__ void r128_emit_state(drm_r128_private_t * dev_priv) static void r128_emit_state(drm_r128_private_t * dev_priv)
{ {
drm_r128_sarea_t *sarea_priv = dev_priv->sarea_priv; drm_r128_sarea_t *sarea_priv = dev_priv->sarea_priv;
unsigned int dirty = sarea_priv->dirty; unsigned int dirty = sarea_priv->dirty;

View File

@ -41,7 +41,6 @@ static DEFINE_SPINLOCK(cpufreq_driver_lock);
/* internal prototypes */ /* internal prototypes */
static int __cpufreq_governor(struct cpufreq_policy *policy, unsigned int event); static int __cpufreq_governor(struct cpufreq_policy *policy, unsigned int event);
static void handle_update(void *data); static void handle_update(void *data);
static inline void adjust_jiffies(unsigned long val, struct cpufreq_freqs *ci);
/** /**
* Two notifier lists: the "policy" list is involved in the * Two notifier lists: the "policy" list is involved in the
@ -127,7 +126,7 @@ static unsigned int debug_ratelimit = 1;
static unsigned int disable_ratelimit = 1; static unsigned int disable_ratelimit = 1;
static DEFINE_SPINLOCK(disable_ratelimit_lock); static DEFINE_SPINLOCK(disable_ratelimit_lock);
static inline void cpufreq_debug_enable_ratelimit(void) static void cpufreq_debug_enable_ratelimit(void)
{ {
unsigned long flags; unsigned long flags;
@ -137,7 +136,7 @@ static inline void cpufreq_debug_enable_ratelimit(void)
spin_unlock_irqrestore(&disable_ratelimit_lock, flags); spin_unlock_irqrestore(&disable_ratelimit_lock, flags);
} }
static inline void cpufreq_debug_disable_ratelimit(void) static void cpufreq_debug_disable_ratelimit(void)
{ {
unsigned long flags; unsigned long flags;
@ -206,7 +205,7 @@ static inline void cpufreq_debug_disable_ratelimit(void) { return; }
static unsigned long l_p_j_ref; static unsigned long l_p_j_ref;
static unsigned int l_p_j_ref_freq; static unsigned int l_p_j_ref_freq;
static inline void adjust_jiffies(unsigned long val, struct cpufreq_freqs *ci) static void adjust_jiffies(unsigned long val, struct cpufreq_freqs *ci)
{ {
if (ci->flags & CPUFREQ_CONST_LOOPS) if (ci->flags & CPUFREQ_CONST_LOOPS)
return; return;

View File

@ -980,7 +980,7 @@ static void cdrom_buffer_sectors (ide_drive_t *drive, unsigned long sector,
* and attempt to recover if there are problems. Returns 0 if everything's * and attempt to recover if there are problems. Returns 0 if everything's
* ok; nonzero if the request has been terminated. * ok; nonzero if the request has been terminated.
*/ */
static inline static
int cdrom_read_check_ireason (ide_drive_t *drive, int len, int ireason) int cdrom_read_check_ireason (ide_drive_t *drive, int len, int ireason)
{ {
if (ireason == 2) if (ireason == 2)
@ -1539,7 +1539,7 @@ int cdrom_queue_packet_command(ide_drive_t *drive, struct request *rq)
/* /*
* Write handling * Write handling
*/ */
static inline int cdrom_write_check_ireason(ide_drive_t *drive, int len, int ireason) static int cdrom_write_check_ireason(ide_drive_t *drive, int len, int ireason)
{ {
/* Two notes about IDE interrupt reason here - 0 means that /* Two notes about IDE interrupt reason here - 0 means that
* the drive wants to receive data from us, 2 means that * the drive wants to receive data from us, 2 means that

View File

@ -477,7 +477,7 @@ static inline int idedisk_supports_lba48(const struct hd_driveid *id)
&& id->lba_capacity_2; && id->lba_capacity_2;
} }
static inline void idedisk_check_hpa(ide_drive_t *drive) static void idedisk_check_hpa(ide_drive_t *drive)
{ {
unsigned long long capacity, set_max; unsigned long long capacity, set_max;
int lba48 = idedisk_supports_lba48(drive->id); int lba48 = idedisk_supports_lba48(drive->id);

View File

@ -308,7 +308,7 @@ static void ide_pio_multi(ide_drive_t *drive, unsigned int write)
ide_pio_sector(drive, write); ide_pio_sector(drive, write);
} }
static inline void ide_pio_datablock(ide_drive_t *drive, struct request *rq, static void ide_pio_datablock(ide_drive_t *drive, struct request *rq,
unsigned int write) unsigned int write)
{ {
if (rq->bio) /* fs request */ if (rq->bio) /* fs request */

View File

@ -856,7 +856,7 @@ static void cm_format_req(struct cm_req_msg *req_msg,
param->private_data_len); param->private_data_len);
} }
static inline int cm_validate_req_param(struct ib_cm_req_param *param) static int cm_validate_req_param(struct ib_cm_req_param *param)
{ {
/* peer-to-peer not supported */ /* peer-to-peer not supported */
if (param->peer_to_peer) if (param->peer_to_peer)
@ -1005,7 +1005,7 @@ static inline int cm_is_active_peer(__be64 local_ca_guid, __be64 remote_ca_guid,
(be32_to_cpu(local_qpn) > be32_to_cpu(remote_qpn)))); (be32_to_cpu(local_qpn) > be32_to_cpu(remote_qpn))));
} }
static inline void cm_format_paths_from_req(struct cm_req_msg *req_msg, static void cm_format_paths_from_req(struct cm_req_msg *req_msg,
struct ib_sa_path_rec *primary_path, struct ib_sa_path_rec *primary_path,
struct ib_sa_path_rec *alt_path) struct ib_sa_path_rec *alt_path)
{ {

View File

@ -358,7 +358,7 @@ hdlc_fill_fifo(struct BCState *bcs)
} }
} }
static inline void static void
HDLC_irq(struct BCState *bcs, u_int stat) { HDLC_irq(struct BCState *bcs, u_int stat) {
int len; int len;
struct sk_buff *skb; struct sk_buff *skb;

View File

@ -476,7 +476,7 @@ Memhscx_fill_fifo(struct BCState *bcs)
} }
} }
static inline void static void
Memhscx_interrupt(struct IsdnCardState *cs, u_char val, u_char hscx) Memhscx_interrupt(struct IsdnCardState *cs, u_char val, u_char hscx)
{ {
u_char r; u_char r;

View File

@ -119,7 +119,7 @@ hscx_fill_fifo(struct BCState *bcs)
} }
} }
static inline void static void
hscx_interrupt(struct IsdnCardState *cs, u_char val, u_char hscx) hscx_interrupt(struct IsdnCardState *cs, u_char val, u_char hscx)
{ {
u_char r; u_char r;
@ -221,7 +221,7 @@ hscx_interrupt(struct IsdnCardState *cs, u_char val, u_char hscx)
} }
} }
static inline void static void
hscx_int_main(struct IsdnCardState *cs, u_char val) hscx_int_main(struct IsdnCardState *cs, u_char val)
{ {

View File

@ -110,7 +110,7 @@ jade_fill_fifo(struct BCState *bcs)
} }
static inline void static void
jade_interrupt(struct IsdnCardState *cs, u_char val, u_char jade) jade_interrupt(struct IsdnCardState *cs, u_char val, u_char jade)
{ {
u_char r; u_char r;

View File

@ -200,7 +200,7 @@ out:
/* if page is completely empty, put it back on the free list, or dealloc it */ /* if page is completely empty, put it back on the free list, or dealloc it */
/* if page was hijacked, unmark the flag so it might get alloced next time */ /* if page was hijacked, unmark the flag so it might get alloced next time */
/* Note: lock should be held when calling this */ /* Note: lock should be held when calling this */
static inline void bitmap_checkfree(struct bitmap *bitmap, unsigned long page) static void bitmap_checkfree(struct bitmap *bitmap, unsigned long page)
{ {
char *ptr; char *ptr;

View File

@ -228,7 +228,7 @@ static struct crypt_iv_operations crypt_iv_essiv_ops = {
}; };
static inline int static int
crypt_convert_scatterlist(struct crypt_config *cc, struct scatterlist *out, crypt_convert_scatterlist(struct crypt_config *cc, struct scatterlist *out,
struct scatterlist *in, unsigned int length, struct scatterlist *in, unsigned int length,
int write, sector_t sector) int write, sector_t sector)

View File

@ -598,7 +598,7 @@ static int dev_create(struct dm_ioctl *param, size_t param_size)
/* /*
* Always use UUID for lookups if it's present, otherwise use name or dev. * Always use UUID for lookups if it's present, otherwise use name or dev.
*/ */
static inline struct hash_cell *__find_device_hash_cell(struct dm_ioctl *param) static struct hash_cell *__find_device_hash_cell(struct dm_ioctl *param)
{ {
if (*param->uuid) if (*param->uuid)
return __get_uuid_cell(param->uuid); return __get_uuid_cell(param->uuid);
@ -608,7 +608,7 @@ static inline struct hash_cell *__find_device_hash_cell(struct dm_ioctl *param)
return dm_get_mdptr(huge_decode_dev(param->dev)); return dm_get_mdptr(huge_decode_dev(param->dev));
} }
static inline struct mapped_device *find_device(struct dm_ioctl *param) static struct mapped_device *find_device(struct dm_ioctl *param)
{ {
struct hash_cell *hc; struct hash_cell *hc;
struct mapped_device *md = NULL; struct mapped_device *md = NULL;

View File

@ -691,7 +691,7 @@ static void copy_callback(int read_err, unsigned int write_err, void *context)
/* /*
* Dispatches the copy operation to kcopyd. * Dispatches the copy operation to kcopyd.
*/ */
static inline void start_copy(struct pending_exception *pe) static void start_copy(struct pending_exception *pe)
{ {
struct dm_snapshot *s = pe->snap; struct dm_snapshot *s = pe->snap;
struct io_region src, dest; struct io_region src, dest;

View File

@ -293,7 +293,7 @@ struct dm_table *dm_get_table(struct mapped_device *md)
* Decrements the number of outstanding ios that a bio has been * Decrements the number of outstanding ios that a bio has been
* cloned into, completing the original io if necc. * cloned into, completing the original io if necc.
*/ */
static inline void dec_pending(struct dm_io *io, int error) static void dec_pending(struct dm_io *io, int error)
{ {
if (error) if (error)
io->error = error; io->error = error;

View File

@ -176,7 +176,7 @@ static void put_all_bios(conf_t *conf, r1bio_t *r1_bio)
} }
} }
static inline void free_r1bio(r1bio_t *r1_bio) static void free_r1bio(r1bio_t *r1_bio)
{ {
conf_t *conf = mddev_to_conf(r1_bio->mddev); conf_t *conf = mddev_to_conf(r1_bio->mddev);
@ -190,7 +190,7 @@ static inline void free_r1bio(r1bio_t *r1_bio)
mempool_free(r1_bio, conf->r1bio_pool); mempool_free(r1_bio, conf->r1bio_pool);
} }
static inline void put_buf(r1bio_t *r1_bio) static void put_buf(r1bio_t *r1_bio)
{ {
conf_t *conf = mddev_to_conf(r1_bio->mddev); conf_t *conf = mddev_to_conf(r1_bio->mddev);
int i; int i;

View File

@ -176,7 +176,7 @@ static void put_all_bios(conf_t *conf, r10bio_t *r10_bio)
} }
} }
static inline void free_r10bio(r10bio_t *r10_bio) static void free_r10bio(r10bio_t *r10_bio)
{ {
conf_t *conf = mddev_to_conf(r10_bio->mddev); conf_t *conf = mddev_to_conf(r10_bio->mddev);
@ -190,7 +190,7 @@ static inline void free_r10bio(r10bio_t *r10_bio)
mempool_free(r10_bio, conf->r10bio_pool); mempool_free(r10_bio, conf->r10bio_pool);
} }
static inline void put_buf(r10bio_t *r10_bio) static void put_buf(r10bio_t *r10_bio)
{ {
conf_t *conf = mddev_to_conf(r10_bio->mddev); conf_t *conf = mddev_to_conf(r10_bio->mddev);

View File

@ -69,7 +69,7 @@
static void print_raid5_conf (raid5_conf_t *conf); static void print_raid5_conf (raid5_conf_t *conf);
static inline void __release_stripe(raid5_conf_t *conf, struct stripe_head *sh) static void __release_stripe(raid5_conf_t *conf, struct stripe_head *sh)
{ {
if (atomic_dec_and_test(&sh->count)) { if (atomic_dec_and_test(&sh->count)) {
if (!list_empty(&sh->lru)) if (!list_empty(&sh->lru))
@ -118,7 +118,7 @@ static inline void remove_hash(struct stripe_head *sh)
hlist_del_init(&sh->hash); hlist_del_init(&sh->hash);
} }
static inline void insert_hash(raid5_conf_t *conf, struct stripe_head *sh) static void insert_hash(raid5_conf_t *conf, struct stripe_head *sh)
{ {
struct hlist_head *hp = stripe_hash(conf, sh->sector); struct hlist_head *hp = stripe_hash(conf, sh->sector);
@ -178,7 +178,7 @@ static int grow_buffers(struct stripe_head *sh, int num)
static void raid5_build_block (struct stripe_head *sh, int i); static void raid5_build_block (struct stripe_head *sh, int i);
static inline void init_stripe(struct stripe_head *sh, sector_t sector, int pd_idx) static void init_stripe(struct stripe_head *sh, sector_t sector, int pd_idx)
{ {
raid5_conf_t *conf = sh->raid_conf; raid5_conf_t *conf = sh->raid_conf;
int disks = conf->raid_disks, i; int disks = conf->raid_disks, i;
@ -1415,7 +1415,7 @@ static void handle_stripe(struct stripe_head *sh)
} }
} }
static inline void raid5_activate_delayed(raid5_conf_t *conf) static void raid5_activate_delayed(raid5_conf_t *conf)
{ {
if (atomic_read(&conf->preread_active_stripes) < IO_THRESHOLD) { if (atomic_read(&conf->preread_active_stripes) < IO_THRESHOLD) {
while (!list_empty(&conf->delayed_list)) { while (!list_empty(&conf->delayed_list)) {
@ -1431,7 +1431,7 @@ static inline void raid5_activate_delayed(raid5_conf_t *conf)
} }
} }
static inline void activate_bit_delay(raid5_conf_t *conf) static void activate_bit_delay(raid5_conf_t *conf)
{ {
/* device_lock is held */ /* device_lock is held */
struct list_head head; struct list_head head;

View File

@ -88,7 +88,7 @@ static inline int raid6_next_disk(int disk, int raid_disks)
static void print_raid6_conf (raid6_conf_t *conf); static void print_raid6_conf (raid6_conf_t *conf);
static inline void __release_stripe(raid6_conf_t *conf, struct stripe_head *sh) static void __release_stripe(raid6_conf_t *conf, struct stripe_head *sh)
{ {
if (atomic_dec_and_test(&sh->count)) { if (atomic_dec_and_test(&sh->count)) {
if (!list_empty(&sh->lru)) if (!list_empty(&sh->lru))
@ -197,7 +197,7 @@ static int grow_buffers(struct stripe_head *sh, int num)
static void raid6_build_block (struct stripe_head *sh, int i); static void raid6_build_block (struct stripe_head *sh, int i);
static inline void init_stripe(struct stripe_head *sh, sector_t sector, int pd_idx) static void init_stripe(struct stripe_head *sh, sector_t sector, int pd_idx)
{ {
raid6_conf_t *conf = sh->raid_conf; raid6_conf_t *conf = sh->raid_conf;
int disks = conf->raid_disks, i; int disks = conf->raid_disks, i;
@ -1577,7 +1577,7 @@ static void handle_stripe(struct stripe_head *sh, struct page *tmp_page)
} }
} }
static inline void raid6_activate_delayed(raid6_conf_t *conf) static void raid6_activate_delayed(raid6_conf_t *conf)
{ {
if (atomic_read(&conf->preread_active_stripes) < IO_THRESHOLD) { if (atomic_read(&conf->preread_active_stripes) < IO_THRESHOLD) {
while (!list_empty(&conf->delayed_list)) { while (!list_empty(&conf->delayed_list)) {
@ -1593,7 +1593,7 @@ static inline void raid6_activate_delayed(raid6_conf_t *conf)
} }
} }
static inline void activate_bit_delay(raid6_conf_t *conf) static void activate_bit_delay(raid6_conf_t *conf)
{ {
/* device_lock is held */ /* device_lock is held */
struct list_head head; struct list_head head;

View File

@ -93,7 +93,7 @@ struct tvp5150 {
int sat; int sat;
}; };
static inline int tvp5150_read(struct i2c_client *c, unsigned char addr) static int tvp5150_read(struct i2c_client *c, unsigned char addr)
{ {
unsigned char buffer[1]; unsigned char buffer[1];
int rc; int rc;

View File

@ -844,7 +844,7 @@ mpt_lan_sdu_send (struct sk_buff *skb, struct net_device *dev)
} }
/*=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=*/ /*=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=*/
static inline void static void
mpt_lan_wake_post_buckets_task(struct net_device *dev, int priority) mpt_lan_wake_post_buckets_task(struct net_device *dev, int priority)
/* /*
* @priority: 0 = put it on the timer queue, 1 = put it on the immediate queue * @priority: 0 = put it on the timer queue, 1 = put it on the immediate queue
@ -866,7 +866,7 @@ mpt_lan_wake_post_buckets_task(struct net_device *dev, int priority)
} }
/*=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=*/ /*=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=-=*/
static inline int static int
mpt_lan_receive_skb(struct net_device *dev, struct sk_buff *skb) mpt_lan_receive_skb(struct net_device *dev, struct sk_buff *skb)
{ {
struct mpt_lan_priv *priv = dev->priv; struct mpt_lan_priv *priv = dev->priv;

View File

@ -138,7 +138,7 @@ static inline int DoC_WaitReady(struct DiskOnChip *doc)
bypass the internal pipeline. Each of 4 delay cycles (read from the NOP register) is bypass the internal pipeline. Each of 4 delay cycles (read from the NOP register) is
required after writing to CDSN Control register, see Software Requirement 11.4 item 3. */ required after writing to CDSN Control register, see Software Requirement 11.4 item 3. */
static inline int DoC_Command(struct DiskOnChip *doc, unsigned char command, static int DoC_Command(struct DiskOnChip *doc, unsigned char command,
unsigned char xtraflags) unsigned char xtraflags)
{ {
void __iomem *docptr = doc->virtadr; void __iomem *docptr = doc->virtadr;

View File

@ -103,7 +103,7 @@ static inline int DoC_WaitReady(void __iomem * docptr)
with the internal pipeline. Each of 4 delay cycles (read from the NOP register) is with the internal pipeline. Each of 4 delay cycles (read from the NOP register) is
required after writing to CDSN Control register, see Software Requirement 11.4 item 3. */ required after writing to CDSN Control register, see Software Requirement 11.4 item 3. */
static inline void DoC_Command(void __iomem * docptr, unsigned char command, static void DoC_Command(void __iomem * docptr, unsigned char command,
unsigned char xtraflags) unsigned char xtraflags)
{ {
/* Assert the CLE (Command Latch Enable) line to the flash chip */ /* Assert the CLE (Command Latch Enable) line to the flash chip */

View File

@ -118,7 +118,7 @@ static inline void DoC_CheckASIC(void __iomem * docptr)
/* DoC_Command: Send a flash command to the flash chip through the Flash /* DoC_Command: Send a flash command to the flash chip through the Flash
* command register. Need 2 Write Pipeline Terminates to complete send. * command register. Need 2 Write Pipeline Terminates to complete send.
*/ */
static inline void DoC_Command(void __iomem * docptr, unsigned char command, static void DoC_Command(void __iomem * docptr, unsigned char command,
unsigned char xtraflags) unsigned char xtraflags)
{ {
WriteDOC(command, docptr, Mplus_FlashCmd); WriteDOC(command, docptr, Mplus_FlashCmd);

View File

@ -1506,7 +1506,7 @@ static inline int __init doc2001plus_init(struct mtd_info *mtd)
return 1; return 1;
} }
static inline int __init doc_probe(unsigned long physadr) static int __init doc_probe(unsigned long physadr)
{ {
unsigned char ChipID; unsigned char ChipID;
struct mtd_info *mtd; struct mtd_info *mtd;

View File

@ -592,7 +592,7 @@ static inline void e100_write_flush(struct nic *nic)
(void)readb(&nic->csr->scb.status); (void)readb(&nic->csr->scb.status);
} }
static inline void e100_enable_irq(struct nic *nic) static void e100_enable_irq(struct nic *nic)
{ {
unsigned long flags; unsigned long flags;
@ -602,7 +602,7 @@ static inline void e100_enable_irq(struct nic *nic)
e100_write_flush(nic); e100_write_flush(nic);
} }
static inline void e100_disable_irq(struct nic *nic) static void e100_disable_irq(struct nic *nic)
{ {
unsigned long flags; unsigned long flags;
@ -791,7 +791,7 @@ static int e100_eeprom_save(struct nic *nic, u16 start, u16 count)
#define E100_WAIT_SCB_TIMEOUT 20000 /* we might have to wait 100ms!!! */ #define E100_WAIT_SCB_TIMEOUT 20000 /* we might have to wait 100ms!!! */
#define E100_WAIT_SCB_FAST 20 /* delay like the old code */ #define E100_WAIT_SCB_FAST 20 /* delay like the old code */
static inline int e100_exec_cmd(struct nic *nic, u8 cmd, dma_addr_t dma_addr) static int e100_exec_cmd(struct nic *nic, u8 cmd, dma_addr_t dma_addr)
{ {
unsigned long flags; unsigned long flags;
unsigned int i; unsigned int i;
@ -822,7 +822,7 @@ err_unlock:
return err; return err;
} }
static inline int e100_exec_cb(struct nic *nic, struct sk_buff *skb, static int e100_exec_cb(struct nic *nic, struct sk_buff *skb,
void (*cb_prepare)(struct nic *, struct cb *, struct sk_buff *)) void (*cb_prepare)(struct nic *, struct cb *, struct sk_buff *))
{ {
struct cb *cb; struct cb *cb;
@ -1567,7 +1567,7 @@ static void e100_watchdog(unsigned long data)
mod_timer(&nic->watchdog, jiffies + E100_WATCHDOG_PERIOD); mod_timer(&nic->watchdog, jiffies + E100_WATCHDOG_PERIOD);
} }
static inline void e100_xmit_prepare(struct nic *nic, struct cb *cb, static void e100_xmit_prepare(struct nic *nic, struct cb *cb,
struct sk_buff *skb) struct sk_buff *skb)
{ {
cb->command = nic->tx_command; cb->command = nic->tx_command;
@ -1617,7 +1617,7 @@ static int e100_xmit_frame(struct sk_buff *skb, struct net_device *netdev)
return 0; return 0;
} }
static inline int e100_tx_clean(struct nic *nic) static int e100_tx_clean(struct nic *nic)
{ {
struct cb *cb; struct cb *cb;
int tx_cleaned = 0; int tx_cleaned = 0;
@ -1728,7 +1728,7 @@ static inline void e100_start_receiver(struct nic *nic, struct rx *rx)
} }
#define RFD_BUF_LEN (sizeof(struct rfd) + VLAN_ETH_FRAME_LEN) #define RFD_BUF_LEN (sizeof(struct rfd) + VLAN_ETH_FRAME_LEN)
static inline int e100_rx_alloc_skb(struct nic *nic, struct rx *rx) static int e100_rx_alloc_skb(struct nic *nic, struct rx *rx)
{ {
if(!(rx->skb = dev_alloc_skb(RFD_BUF_LEN + NET_IP_ALIGN))) if(!(rx->skb = dev_alloc_skb(RFD_BUF_LEN + NET_IP_ALIGN)))
return -ENOMEM; return -ENOMEM;
@ -1762,7 +1762,7 @@ static inline int e100_rx_alloc_skb(struct nic *nic, struct rx *rx)
return 0; return 0;
} }
static inline int e100_rx_indicate(struct nic *nic, struct rx *rx, static int e100_rx_indicate(struct nic *nic, struct rx *rx,
unsigned int *work_done, unsigned int work_to_do) unsigned int *work_done, unsigned int work_to_do)
{ {
struct sk_buff *skb = rx->skb; struct sk_buff *skb = rx->skb;
@ -1822,7 +1822,7 @@ static inline int e100_rx_indicate(struct nic *nic, struct rx *rx,
return 0; return 0;
} }
static inline void e100_rx_clean(struct nic *nic, unsigned int *work_done, static void e100_rx_clean(struct nic *nic, unsigned int *work_done,
unsigned int work_to_do) unsigned int work_to_do)
{ {
struct rx *rx; struct rx *rx;

View File

@ -94,7 +94,7 @@ static inline int card_wait_for_busy_clear(const int ioaddr[],
const char* name); const char* name);
static inline int card_wait_for_ready(const int ioaddr[], const char* name, static inline int card_wait_for_ready(const int ioaddr[], const char* name,
unsigned char in[]); unsigned char in[]);
static inline int card_send_command(const int ioaddr[], const char* name, static int card_send_command(const int ioaddr[], const char* name,
const unsigned char out[], unsigned char in[]); const unsigned char out[], unsigned char in[]);
/* SB1000 hardware routines to be used during frame rx interrupt */ /* SB1000 hardware routines to be used during frame rx interrupt */
@ -309,7 +309,7 @@ card_wait_for_ready(const int ioaddr[], const char* name, unsigned char in[])
} }
/* Card Send Command (cannot be used during an interrupt) */ /* Card Send Command (cannot be used during an interrupt) */
static inline int static int
card_send_command(const int ioaddr[], const char* name, card_send_command(const int ioaddr[], const char* name,
const unsigned char out[], unsigned char in[]) const unsigned char out[], unsigned char in[])
{ {

View File

@ -435,7 +435,7 @@ static void hostap_rx_sta_beacon(local_info_t *local, struct sk_buff *skb,
} }
static inline int static int
hostap_rx_frame_mgmt(local_info_t *local, struct sk_buff *skb, hostap_rx_frame_mgmt(local_info_t *local, struct sk_buff *skb,
struct hostap_80211_rx_status *rx_stats, u16 type, struct hostap_80211_rx_status *rx_stats, u16 type,
u16 stype) u16 stype)
@ -499,7 +499,7 @@ hostap_rx_frame_mgmt(local_info_t *local, struct sk_buff *skb,
/* Called only as a tasklet (software IRQ) */ /* Called only as a tasklet (software IRQ) */
static inline struct net_device *prism2_rx_get_wds(local_info_t *local, static struct net_device *prism2_rx_get_wds(local_info_t *local,
u8 *addr) u8 *addr)
{ {
struct hostap_interface *iface = NULL; struct hostap_interface *iface = NULL;
@ -519,7 +519,7 @@ static inline struct net_device *prism2_rx_get_wds(local_info_t *local,
} }
static inline int static int
hostap_rx_frame_wds(local_info_t *local, struct ieee80211_hdr_4addr *hdr, hostap_rx_frame_wds(local_info_t *local, struct ieee80211_hdr_4addr *hdr,
u16 fc, struct net_device **wds) u16 fc, struct net_device **wds)
{ {
@ -615,7 +615,7 @@ static int hostap_is_eapol_frame(local_info_t *local, struct sk_buff *skb)
/* Called only as a tasklet (software IRQ) */ /* Called only as a tasklet (software IRQ) */
static inline int static int
hostap_rx_frame_decrypt(local_info_t *local, struct sk_buff *skb, hostap_rx_frame_decrypt(local_info_t *local, struct sk_buff *skb,
struct ieee80211_crypt_data *crypt) struct ieee80211_crypt_data *crypt)
{ {
@ -654,7 +654,7 @@ hostap_rx_frame_decrypt(local_info_t *local, struct sk_buff *skb,
/* Called only as a tasklet (software IRQ) */ /* Called only as a tasklet (software IRQ) */
static inline int static int
hostap_rx_frame_decrypt_msdu(local_info_t *local, struct sk_buff *skb, hostap_rx_frame_decrypt_msdu(local_info_t *local, struct sk_buff *skb,
int keyidx, struct ieee80211_crypt_data *crypt) int keyidx, struct ieee80211_crypt_data *crypt)
{ {

View File

@ -253,7 +253,7 @@ static void prism2_clear_cmd_queue(local_info_t *local)
* @dev: pointer to net_device * @dev: pointer to net_device
* @entry: Prism2 command queue entry to be issued * @entry: Prism2 command queue entry to be issued
*/ */
static inline int hfa384x_cmd_issue(struct net_device *dev, static int hfa384x_cmd_issue(struct net_device *dev,
struct hostap_cmd_queue *entry) struct hostap_cmd_queue *entry)
{ {
struct hostap_interface *iface; struct hostap_interface *iface;
@ -743,7 +743,7 @@ static void prism2_cmd_ev(struct net_device *dev)
} }
static inline int hfa384x_wait_offset(struct net_device *dev, u16 o_off) static int hfa384x_wait_offset(struct net_device *dev, u16 o_off)
{ {
int tries = HFA384X_BAP_BUSY_TIMEOUT; int tries = HFA384X_BAP_BUSY_TIMEOUT;
int res = HFA384X_INW(o_off) & HFA384X_OFFSET_BUSY; int res = HFA384X_INW(o_off) & HFA384X_OFFSET_BUSY;
@ -1904,7 +1904,7 @@ fail:
* and will try to get the correct fid eventually. */ * and will try to get the correct fid eventually. */
#define EXTRA_FID_READ_TESTS #define EXTRA_FID_READ_TESTS
static inline u16 prism2_read_fid_reg(struct net_device *dev, u16 reg) static u16 prism2_read_fid_reg(struct net_device *dev, u16 reg)
{ {
#ifdef EXTRA_FID_READ_TESTS #ifdef EXTRA_FID_READ_TESTS
u16 val, val2, val3; u16 val, val2, val3;
@ -2581,7 +2581,7 @@ static void prism2_ev_tick(struct net_device *dev)
/* Called only from hardware IRQ */ /* Called only from hardware IRQ */
static inline void prism2_check_magic(local_info_t *local) static void prism2_check_magic(local_info_t *local)
{ {
/* at least PCI Prism2.5 with bus mastering seems to sometimes /* at least PCI Prism2.5 with bus mastering seems to sometimes
* return 0x0000 in SWSUPPORT0 for unknown reason, but re-reading the * return 0x0000 in SWSUPPORT0 for unknown reason, but re-reading the

View File

@ -411,7 +411,7 @@ static inline void write_nic_dword_auto_inc(struct net_device *dev, u32 val)
write_register(dev, IPW_REG_AUTOINCREMENT_DATA, val); write_register(dev, IPW_REG_AUTOINCREMENT_DATA, val);
} }
static inline void write_nic_memory(struct net_device *dev, u32 addr, u32 len, static void write_nic_memory(struct net_device *dev, u32 addr, u32 len,
const u8 * buf) const u8 * buf)
{ {
u32 aligned_addr; u32 aligned_addr;
@ -449,7 +449,7 @@ static inline void write_nic_memory(struct net_device *dev, u32 addr, u32 len,
*buf); *buf);
} }
static inline void read_nic_memory(struct net_device *dev, u32 addr, u32 len, static void read_nic_memory(struct net_device *dev, u32 addr, u32 len,
u8 * buf) u8 * buf)
{ {
u32 aligned_addr; u32 aligned_addr;
@ -657,7 +657,7 @@ static void printk_buf(int level, const u8 * data, u32 len)
#define MAX_RESET_BACKOFF 10 #define MAX_RESET_BACKOFF 10
static inline void schedule_reset(struct ipw2100_priv *priv) static void schedule_reset(struct ipw2100_priv *priv)
{ {
unsigned long now = get_seconds(); unsigned long now = get_seconds();
@ -1130,7 +1130,7 @@ static inline void ipw2100_hw_set_gpio(struct ipw2100_priv *priv)
write_register(priv->net_dev, IPW_REG_GPIO, reg); write_register(priv->net_dev, IPW_REG_GPIO, reg);
} }
static inline int rf_kill_active(struct ipw2100_priv *priv) static int rf_kill_active(struct ipw2100_priv *priv)
{ {
#define MAX_RF_KILL_CHECKS 5 #define MAX_RF_KILL_CHECKS 5
#define RF_KILL_CHECK_DELAY 40 #define RF_KILL_CHECK_DELAY 40
@ -2177,7 +2177,7 @@ static const char *frame_types[] = {
}; };
#endif #endif
static inline int ipw2100_alloc_skb(struct ipw2100_priv *priv, static int ipw2100_alloc_skb(struct ipw2100_priv *priv,
struct ipw2100_rx_packet *packet) struct ipw2100_rx_packet *packet)
{ {
packet->skb = dev_alloc_skb(sizeof(struct ipw2100_rx)); packet->skb = dev_alloc_skb(sizeof(struct ipw2100_rx));
@ -2201,7 +2201,7 @@ static inline int ipw2100_alloc_skb(struct ipw2100_priv *priv,
#define SEARCH_SNAPSHOT 1 #define SEARCH_SNAPSHOT 1
#define SNAPSHOT_ADDR(ofs) (priv->snapshot[((ofs) >> 12) & 0xff] + ((ofs) & 0xfff)) #define SNAPSHOT_ADDR(ofs) (priv->snapshot[((ofs) >> 12) & 0xff] + ((ofs) & 0xfff))
static inline int ipw2100_snapshot_alloc(struct ipw2100_priv *priv) static int ipw2100_snapshot_alloc(struct ipw2100_priv *priv)
{ {
int i; int i;
if (priv->snapshot[0]) if (priv->snapshot[0])
@ -2221,7 +2221,7 @@ static inline int ipw2100_snapshot_alloc(struct ipw2100_priv *priv)
return 1; return 1;
} }
static inline void ipw2100_snapshot_free(struct ipw2100_priv *priv) static void ipw2100_snapshot_free(struct ipw2100_priv *priv)
{ {
int i; int i;
if (!priv->snapshot[0]) if (!priv->snapshot[0])
@ -2231,7 +2231,7 @@ static inline void ipw2100_snapshot_free(struct ipw2100_priv *priv)
priv->snapshot[0] = NULL; priv->snapshot[0] = NULL;
} }
static inline u32 ipw2100_match_buf(struct ipw2100_priv *priv, u8 * in_buf, static u32 ipw2100_match_buf(struct ipw2100_priv *priv, u8 * in_buf,
size_t len, int mode) size_t len, int mode)
{ {
u32 i, j; u32 i, j;
@ -2288,7 +2288,7 @@ static inline u32 ipw2100_match_buf(struct ipw2100_priv *priv, u8 * in_buf,
static u8 packet_data[IPW_RX_NIC_BUFFER_LENGTH]; static u8 packet_data[IPW_RX_NIC_BUFFER_LENGTH];
#endif #endif
static inline void ipw2100_corruption_detected(struct ipw2100_priv *priv, int i) static void ipw2100_corruption_detected(struct ipw2100_priv *priv, int i)
{ {
#ifdef CONFIG_IPW2100_DEBUG_C3 #ifdef CONFIG_IPW2100_DEBUG_C3
struct ipw2100_status *status = &priv->status_queue.drv[i]; struct ipw2100_status *status = &priv->status_queue.drv[i];
@ -2346,7 +2346,7 @@ static inline void ipw2100_corruption_detected(struct ipw2100_priv *priv, int i)
schedule_reset(priv); schedule_reset(priv);
} }
static inline void isr_rx(struct ipw2100_priv *priv, int i, static void isr_rx(struct ipw2100_priv *priv, int i,
struct ieee80211_rx_stats *stats) struct ieee80211_rx_stats *stats)
{ {
struct ipw2100_status *status = &priv->status_queue.drv[i]; struct ipw2100_status *status = &priv->status_queue.drv[i];
@ -2425,7 +2425,7 @@ static inline void isr_rx(struct ipw2100_priv *priv, int i,
priv->rx_queue.drv[i].host_addr = packet->dma_addr; priv->rx_queue.drv[i].host_addr = packet->dma_addr;
} }
static inline int ipw2100_corruption_check(struct ipw2100_priv *priv, int i) static int ipw2100_corruption_check(struct ipw2100_priv *priv, int i)
{ {
struct ipw2100_status *status = &priv->status_queue.drv[i]; struct ipw2100_status *status = &priv->status_queue.drv[i];
struct ipw2100_rx *u = priv->rx_buffers[i].rxp; struct ipw2100_rx *u = priv->rx_buffers[i].rxp;
@ -2481,7 +2481,7 @@ static inline int ipw2100_corruption_check(struct ipw2100_priv *priv, int i)
* The WRITE index is cached in the variable 'priv->rx_queue.next'. * The WRITE index is cached in the variable 'priv->rx_queue.next'.
* *
*/ */
static inline void __ipw2100_rx_process(struct ipw2100_priv *priv) static void __ipw2100_rx_process(struct ipw2100_priv *priv)
{ {
struct ipw2100_bd_queue *rxq = &priv->rx_queue; struct ipw2100_bd_queue *rxq = &priv->rx_queue;
struct ipw2100_status_queue *sq = &priv->status_queue; struct ipw2100_status_queue *sq = &priv->status_queue;
@ -2634,7 +2634,7 @@ static inline void __ipw2100_rx_process(struct ipw2100_priv *priv)
* for use by future command and data packets. * for use by future command and data packets.
* *
*/ */
static inline int __ipw2100_tx_process(struct ipw2100_priv *priv) static int __ipw2100_tx_process(struct ipw2100_priv *priv)
{ {
struct ipw2100_bd_queue *txq = &priv->tx_queue; struct ipw2100_bd_queue *txq = &priv->tx_queue;
struct ipw2100_bd *tbd; struct ipw2100_bd *tbd;

View File

@ -813,7 +813,7 @@ static void ipw_bg_led_link_off(void *data)
up(&priv->sem); up(&priv->sem);
} }
static inline void __ipw_led_activity_on(struct ipw_priv *priv) static void __ipw_led_activity_on(struct ipw_priv *priv)
{ {
u32 led; u32 led;
@ -1508,7 +1508,7 @@ static ssize_t store_direct_dword(struct device *d,
static DEVICE_ATTR(direct_dword, S_IWUSR | S_IRUGO, static DEVICE_ATTR(direct_dword, S_IWUSR | S_IRUGO,
show_direct_dword, store_direct_dword); show_direct_dword, store_direct_dword);
static inline int rf_kill_active(struct ipw_priv *priv) static int rf_kill_active(struct ipw_priv *priv)
{ {
if (0 == (ipw_read32(priv, 0x30) & 0x10000)) if (0 == (ipw_read32(priv, 0x30) & 0x10000))
priv->status |= STATUS_RF_KILL_HW; priv->status |= STATUS_RF_KILL_HW;
@ -2359,7 +2359,7 @@ static inline void eeprom_write_reg(struct ipw_priv *p, u32 data)
} }
/* perform a chip select operation */ /* perform a chip select operation */
static inline void eeprom_cs(struct ipw_priv *priv) static void eeprom_cs(struct ipw_priv *priv)
{ {
eeprom_write_reg(priv, 0); eeprom_write_reg(priv, 0);
eeprom_write_reg(priv, EEPROM_BIT_CS); eeprom_write_reg(priv, EEPROM_BIT_CS);
@ -2368,7 +2368,7 @@ static inline void eeprom_cs(struct ipw_priv *priv)
} }
/* perform a chip select operation */ /* perform a chip select operation */
static inline void eeprom_disable_cs(struct ipw_priv *priv) static void eeprom_disable_cs(struct ipw_priv *priv)
{ {
eeprom_write_reg(priv, EEPROM_BIT_CS); eeprom_write_reg(priv, EEPROM_BIT_CS);
eeprom_write_reg(priv, 0); eeprom_write_reg(priv, 0);
@ -2475,7 +2475,7 @@ static void ipw_eeprom_init_sram(struct ipw_priv *priv)
IPW_DEBUG_TRACE("<<\n"); IPW_DEBUG_TRACE("<<\n");
} }
static inline void ipw_zero_memory(struct ipw_priv *priv, u32 start, u32 count) static void ipw_zero_memory(struct ipw_priv *priv, u32 start, u32 count)
{ {
count >>= 2; count >>= 2;
if (!count) if (!count)
@ -2772,7 +2772,7 @@ static inline int ipw_alive(struct ipw_priv *priv)
return ipw_read32(priv, 0x90) == 0xd55555d5; return ipw_read32(priv, 0x90) == 0xd55555d5;
} }
static inline int ipw_poll_bit(struct ipw_priv *priv, u32 addr, u32 mask, static int ipw_poll_bit(struct ipw_priv *priv, u32 addr, u32 mask,
int timeout) int timeout)
{ {
int i = 0; int i = 0;
@ -3150,7 +3150,7 @@ static int ipw_get_fw(struct ipw_priv *priv,
#define IPW_RX_BUF_SIZE (3000) #define IPW_RX_BUF_SIZE (3000)
static inline void ipw_rx_queue_reset(struct ipw_priv *priv, static void ipw_rx_queue_reset(struct ipw_priv *priv,
struct ipw_rx_queue *rxq) struct ipw_rx_queue *rxq)
{ {
unsigned long flags; unsigned long flags;
@ -3608,7 +3608,7 @@ static void ipw_tx_queue_free(struct ipw_priv *priv)
ipw_queue_tx_free(priv, &priv->txq[3]); ipw_queue_tx_free(priv, &priv->txq[3]);
} }
static inline void ipw_create_bssid(struct ipw_priv *priv, u8 * bssid) static void ipw_create_bssid(struct ipw_priv *priv, u8 * bssid)
{ {
/* First 3 bytes are manufacturer */ /* First 3 bytes are manufacturer */
bssid[0] = priv->mac_addr[0]; bssid[0] = priv->mac_addr[0];
@ -3622,7 +3622,7 @@ static inline void ipw_create_bssid(struct ipw_priv *priv, u8 * bssid)
bssid[0] |= 0x02; /* set local assignment bit (IEEE802) */ bssid[0] |= 0x02; /* set local assignment bit (IEEE802) */
} }
static inline u8 ipw_add_station(struct ipw_priv *priv, u8 * bssid) static u8 ipw_add_station(struct ipw_priv *priv, u8 * bssid)
{ {
struct ipw_station_entry entry; struct ipw_station_entry entry;
int i; int i;
@ -3655,7 +3655,7 @@ static inline u8 ipw_add_station(struct ipw_priv *priv, u8 * bssid)
return i; return i;
} }
static inline u8 ipw_find_station(struct ipw_priv *priv, u8 * bssid) static u8 ipw_find_station(struct ipw_priv *priv, u8 * bssid)
{ {
int i; int i;
@ -3794,7 +3794,7 @@ static void inline average_init(struct average *avg)
memset(avg, 0, sizeof(*avg)); memset(avg, 0, sizeof(*avg));
} }
static void inline average_add(struct average *avg, s16 val) static void average_add(struct average *avg, s16 val)
{ {
avg->sum -= avg->entries[avg->pos]; avg->sum -= avg->entries[avg->pos];
avg->sum += val; avg->sum += val;
@ -3805,7 +3805,7 @@ static void inline average_add(struct average *avg, s16 val)
} }
} }
static s16 inline average_value(struct average *avg) static s16 average_value(struct average *avg)
{ {
if (!unlikely(avg->init)) { if (!unlikely(avg->init)) {
if (avg->pos) if (avg->pos)
@ -3847,7 +3847,7 @@ static void ipw_reset_stats(struct ipw_priv *priv)
} }
static inline u32 ipw_get_max_rate(struct ipw_priv *priv) static u32 ipw_get_max_rate(struct ipw_priv *priv)
{ {
u32 i = 0x80000000; u32 i = 0x80000000;
u32 mask = priv->rates_mask; u32 mask = priv->rates_mask;
@ -4087,7 +4087,7 @@ static void ipw_bg_gather_stats(void *data)
* roaming_threshold -> disassociate_threshold, scan and roam for better signal. * roaming_threshold -> disassociate_threshold, scan and roam for better signal.
* Above disassociate threshold, give up and stop scanning. * Above disassociate threshold, give up and stop scanning.
* Roaming is disabled if disassociate_threshold <= roaming_threshold */ * Roaming is disabled if disassociate_threshold <= roaming_threshold */
static inline void ipw_handle_missed_beacon(struct ipw_priv *priv, static void ipw_handle_missed_beacon(struct ipw_priv *priv,
int missed_count) int missed_count)
{ {
priv->notif_missed_beacons = missed_count; priv->notif_missed_beacons = missed_count;
@ -4157,7 +4157,7 @@ static inline void ipw_handle_missed_beacon(struct ipw_priv *priv,
* Handle host notification packet. * Handle host notification packet.
* Called from interrupt routine * Called from interrupt routine
*/ */
static inline void ipw_rx_notification(struct ipw_priv *priv, static void ipw_rx_notification(struct ipw_priv *priv,
struct ipw_rx_notification *notif) struct ipw_rx_notification *notif)
{ {
notif->size = le16_to_cpu(notif->size); notif->size = le16_to_cpu(notif->size);
@ -5095,7 +5095,7 @@ static int ipw_compatible_rates(struct ipw_priv *priv,
return 1; return 1;
} }
static inline void ipw_copy_rates(struct ipw_supported_rates *dest, static void ipw_copy_rates(struct ipw_supported_rates *dest,
const struct ipw_supported_rates *src) const struct ipw_supported_rates *src)
{ {
u8 i; u8 i;
@ -5856,7 +5856,7 @@ static void ipw_debug_config(struct ipw_priv *priv)
#define ipw_debug_config(x) do {} while (0) #define ipw_debug_config(x) do {} while (0)
#endif #endif
static inline void ipw_set_fixed_rate(struct ipw_priv *priv, int mode) static void ipw_set_fixed_rate(struct ipw_priv *priv, int mode)
{ {
/* TODO: Verify that this works... */ /* TODO: Verify that this works... */
struct ipw_fixed_rate fr = { struct ipw_fixed_rate fr = {
@ -7634,7 +7634,7 @@ static void ipw_handle_data_packet_monitor(struct ipw_priv *priv,
} }
#endif #endif
static inline int is_network_packet(struct ipw_priv *priv, static int is_network_packet(struct ipw_priv *priv,
struct ieee80211_hdr_4addr *header) struct ieee80211_hdr_4addr *header)
{ {
/* Filter incoming packets to determine if they are targetted toward /* Filter incoming packets to determine if they are targetted toward
@ -7672,7 +7672,7 @@ static inline int is_network_packet(struct ipw_priv *priv,
#define IPW_PACKET_RETRY_TIME HZ #define IPW_PACKET_RETRY_TIME HZ
static inline int is_duplicate_packet(struct ipw_priv *priv, static int is_duplicate_packet(struct ipw_priv *priv,
struct ieee80211_hdr_4addr *header) struct ieee80211_hdr_4addr *header)
{ {
u16 sc = le16_to_cpu(header->seq_ctl); u16 sc = le16_to_cpu(header->seq_ctl);
@ -9581,7 +9581,7 @@ static struct iw_statistics *ipw_get_wireless_stats(struct net_device *dev)
/* net device stuff */ /* net device stuff */
static inline void init_sys_config(struct ipw_sys_config *sys_config) static void init_sys_config(struct ipw_sys_config *sys_config)
{ {
memset(sys_config, 0, sizeof(struct ipw_sys_config)); memset(sys_config, 0, sizeof(struct ipw_sys_config));
sys_config->bt_coexistence = 1; /* We may need to look into prvStaBtConfig */ sys_config->bt_coexistence = 1; /* We may need to look into prvStaBtConfig */
@ -9627,7 +9627,7 @@ modify to send one tfd per fragment instead of using chunking. otherwise
we need to heavily modify the ieee80211_skb_to_txb. we need to heavily modify the ieee80211_skb_to_txb.
*/ */
static inline int ipw_tx_skb(struct ipw_priv *priv, struct ieee80211_txb *txb, static int ipw_tx_skb(struct ipw_priv *priv, struct ieee80211_txb *txb,
int pri) int pri)
{ {
struct ieee80211_hdr_3addr *hdr = (struct ieee80211_hdr_3addr *) struct ieee80211_hdr_3addr *hdr = (struct ieee80211_hdr_3addr *)

View File

@ -102,7 +102,7 @@ static inline void hacr_write(unsigned long ioaddr, u16 hacr)
* Write to card's Host Adapter Command Register. Include a delay for * Write to card's Host Adapter Command Register. Include a delay for
* those times when it is needed. * those times when it is needed.
*/ */
static inline void hacr_write_slow(unsigned long ioaddr, u16 hacr) static void hacr_write_slow(unsigned long ioaddr, u16 hacr)
{ {
hacr_write(ioaddr, hacr); hacr_write(ioaddr, hacr);
/* delay might only be needed sometimes */ /* delay might only be needed sometimes */
@ -242,7 +242,7 @@ static void psa_write(unsigned long ioaddr, u16 hacr, int o, /* Offset in PSA */
* The Windows drivers don't use the CRC, but the AP and the PtP tool * The Windows drivers don't use the CRC, but the AP and the PtP tool
* depend on it. * depend on it.
*/ */
static inline u16 psa_crc(u8 * psa, /* The PSA */ static u16 psa_crc(u8 * psa, /* The PSA */
int size) int size)
{ /* Number of short for CRC */ { /* Number of short for CRC */
int byte_cnt; /* Loop on the PSA */ int byte_cnt; /* Loop on the PSA */
@ -310,7 +310,7 @@ static void update_psa_checksum(struct net_device * dev, unsigned long ioaddr, u
/* /*
* Write 1 byte to the MMC. * Write 1 byte to the MMC.
*/ */
static inline void mmc_out(unsigned long ioaddr, u16 o, u8 d) static void mmc_out(unsigned long ioaddr, u16 o, u8 d)
{ {
int count = 0; int count = 0;
@ -326,7 +326,7 @@ static inline void mmc_out(unsigned long ioaddr, u16 o, u8 d)
* Routine to write bytes to the Modem Management Controller. * Routine to write bytes to the Modem Management Controller.
* We start at the end because it is the way it should be! * We start at the end because it is the way it should be!
*/ */
static inline void mmc_write(unsigned long ioaddr, u8 o, u8 * b, int n) static void mmc_write(unsigned long ioaddr, u8 o, u8 * b, int n)
{ {
o += n; o += n;
b += n; b += n;
@ -340,7 +340,7 @@ static inline void mmc_write(unsigned long ioaddr, u8 o, u8 * b, int n)
* Read a byte from the MMC. * Read a byte from the MMC.
* Optimised version for 1 byte, avoid using memory. * Optimised version for 1 byte, avoid using memory.
*/ */
static inline u8 mmc_in(unsigned long ioaddr, u16 o) static u8 mmc_in(unsigned long ioaddr, u16 o)
{ {
int count = 0; int count = 0;
@ -587,7 +587,7 @@ static void wv_ack(struct net_device * dev)
* Set channel attention bit and busy wait until command has * Set channel attention bit and busy wait until command has
* completed, then acknowledge completion of the command. * completed, then acknowledge completion of the command.
*/ */
static inline int wv_synchronous_cmd(struct net_device * dev, const char *str) static int wv_synchronous_cmd(struct net_device * dev, const char *str)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;
@ -633,7 +633,7 @@ static inline int wv_synchronous_cmd(struct net_device * dev, const char *str)
* Configuration commands completion interrupt. * Configuration commands completion interrupt.
* Check if done, and if OK. * Check if done, and if OK.
*/ */
static inline int static int
wv_config_complete(struct net_device * dev, unsigned long ioaddr, net_local * lp) wv_config_complete(struct net_device * dev, unsigned long ioaddr, net_local * lp)
{ {
unsigned short mcs_addr; unsigned short mcs_addr;
@ -843,7 +843,7 @@ if (lp->tx_n_in_use > 0)
* wavelan_interrupt is not an option), so you may experience * wavelan_interrupt is not an option), so you may experience
* delays sometimes. * delays sometimes.
*/ */
static inline void wv_82586_reconfig(struct net_device * dev) static void wv_82586_reconfig(struct net_device * dev)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
unsigned long flags; unsigned long flags;
@ -1281,7 +1281,7 @@ static inline void wv_packet_info(u8 * p, /* Packet to dump */
* This is the information which is displayed by the driver at startup. * This is the information which is displayed by the driver at startup.
* There are lots of flags for configuring it to your liking. * There are lots of flags for configuring it to your liking.
*/ */
static inline void wv_init_info(struct net_device * dev) static void wv_init_info(struct net_device * dev)
{ {
short ioaddr = dev->base_addr; short ioaddr = dev->base_addr;
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
@ -1502,7 +1502,7 @@ static int wavelan_set_mac_address(struct net_device * dev, void *addr)
* It's a bit complicated and you don't really want to look into it. * It's a bit complicated and you don't really want to look into it.
* (called in wavelan_ioctl) * (called in wavelan_ioctl)
*/ */
static inline int wv_set_frequency(unsigned long ioaddr, /* I/O port of the card */ static int wv_set_frequency(unsigned long ioaddr, /* I/O port of the card */
iw_freq * frequency) iw_freq * frequency)
{ {
const int BAND_NUM = 10; /* Number of bands */ const int BAND_NUM = 10; /* Number of bands */
@ -1677,7 +1677,7 @@ static inline int wv_set_frequency(unsigned long ioaddr, /* I/O port of the card
/* /*
* Give the list of available frequencies. * Give the list of available frequencies.
*/ */
static inline int wv_frequency_list(unsigned long ioaddr, /* I/O port of the card */ static int wv_frequency_list(unsigned long ioaddr, /* I/O port of the card */
iw_freq * list, /* List of frequencies to fill */ iw_freq * list, /* List of frequencies to fill */
int max) int max)
{ /* Maximum number of frequencies */ { /* Maximum number of frequencies */
@ -2489,7 +2489,7 @@ static iw_stats *wavelan_get_wireless_stats(struct net_device * dev)
* Note: if any errors occur, the packet is "dropped on the floor". * Note: if any errors occur, the packet is "dropped on the floor".
* (called by wv_packet_rcv()) * (called by wv_packet_rcv())
*/ */
static inline void static void
wv_packet_read(struct net_device * dev, u16 buf_off, int sksize) wv_packet_read(struct net_device * dev, u16 buf_off, int sksize)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
@ -2585,7 +2585,7 @@ wv_packet_read(struct net_device * dev, u16 buf_off, int sksize)
* (called in wavelan_interrupt()). * (called in wavelan_interrupt()).
* Note : the spinlock is already grabbed for us. * Note : the spinlock is already grabbed for us.
*/ */
static inline void wv_receive(struct net_device * dev) static void wv_receive(struct net_device * dev)
{ {
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
@ -2768,7 +2768,7 @@ static inline void wv_receive(struct net_device * dev)
* *
* (called in wavelan_packet_xmit()) * (called in wavelan_packet_xmit())
*/ */
static inline int wv_packet_write(struct net_device * dev, void *buf, short length) static int wv_packet_write(struct net_device * dev, void *buf, short length)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;
@ -2964,7 +2964,7 @@ static int wavelan_packet_xmit(struct sk_buff *skb, struct net_device * dev)
* Routine to initialize the Modem Management Controller. * Routine to initialize the Modem Management Controller.
* (called by wv_hw_reset()) * (called by wv_hw_reset())
*/ */
static inline int wv_mmc_init(struct net_device * dev) static int wv_mmc_init(struct net_device * dev)
{ {
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
@ -3136,7 +3136,7 @@ static inline int wv_mmc_init(struct net_device * dev)
* Start the receive unit. * Start the receive unit.
* (called by wv_hw_reset()) * (called by wv_hw_reset())
*/ */
static inline int wv_ru_start(struct net_device * dev) static int wv_ru_start(struct net_device * dev)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;
@ -3228,7 +3228,7 @@ static inline int wv_ru_start(struct net_device * dev)
* *
* (called by wv_hw_reset()) * (called by wv_hw_reset())
*/ */
static inline int wv_cu_start(struct net_device * dev) static int wv_cu_start(struct net_device * dev)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;
@ -3329,7 +3329,7 @@ static inline int wv_cu_start(struct net_device * dev)
* *
* (called by wv_hw_reset()) * (called by wv_hw_reset())
*/ */
static inline int wv_82586_start(struct net_device * dev) static int wv_82586_start(struct net_device * dev)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;
@ -3641,7 +3641,7 @@ static void wv_82586_config(struct net_device * dev)
* WaveLAN controller (i82586). * WaveLAN controller (i82586).
* (called by wavelan_close()) * (called by wavelan_close())
*/ */
static inline void wv_82586_stop(struct net_device * dev) static void wv_82586_stop(struct net_device * dev)
{ {
net_local *lp = (net_local *) dev->priv; net_local *lp = (net_local *) dev->priv;
unsigned long ioaddr = dev->base_addr; unsigned long ioaddr = dev->base_addr;

View File

@ -1290,7 +1290,7 @@ static void aic7xxx_check_scbs(struct aic7xxx_host *p, char *buffer);
* *
***************************************************************************/ ***************************************************************************/
static inline unsigned char static unsigned char
aic_inb(struct aic7xxx_host *p, long port) aic_inb(struct aic7xxx_host *p, long port)
{ {
#ifdef MMAPIO #ifdef MMAPIO
@ -1309,7 +1309,7 @@ aic_inb(struct aic7xxx_host *p, long port)
#endif #endif
} }
static inline void static void
aic_outb(struct aic7xxx_host *p, unsigned char val, long port) aic_outb(struct aic7xxx_host *p, unsigned char val, long port)
{ {
#ifdef MMAPIO #ifdef MMAPIO

View File

@ -1418,7 +1418,7 @@ iscsi_data_digest_init(struct iscsi_conn *conn, struct iscsi_cmd_task *ctask)
ctask->digest_count = 4; ctask->digest_count = 4;
} }
static inline int static int
iscsi_digest_final_send(struct iscsi_conn *conn, struct iscsi_cmd_task *ctask, iscsi_digest_final_send(struct iscsi_conn *conn, struct iscsi_cmd_task *ctask,
struct iscsi_buf *buf, uint32_t *digest, int final) struct iscsi_buf *buf, uint32_t *digest, int final)
{ {

View File

@ -1747,7 +1747,7 @@ static const struct {
{ ATA_SHIFT_PIO, XFER_PIO_0 }, { ATA_SHIFT_PIO, XFER_PIO_0 },
}; };
static inline u8 base_from_shift(unsigned int shift) static u8 base_from_shift(unsigned int shift)
{ {
int i; int i;

View File

@ -1266,7 +1266,7 @@ megaraid_mbox_teardown_dma_pools(adapter_t *adapter)
* return the scb from the head of the free list. NULL if there are none * return the scb from the head of the free list. NULL if there are none
* available * available
**/ **/
static inline scb_t * static scb_t *
megaraid_alloc_scb(adapter_t *adapter, struct scsi_cmnd *scp) megaraid_alloc_scb(adapter_t *adapter, struct scsi_cmnd *scp)
{ {
struct list_head *head = &adapter->kscb_pool; struct list_head *head = &adapter->kscb_pool;
@ -1329,7 +1329,7 @@ megaraid_dealloc_scb(adapter_t *adapter, scb_t *scb)
* *
* prepare the scatter-gather list * prepare the scatter-gather list
*/ */
static inline int static int
megaraid_mbox_mksgl(adapter_t *adapter, scb_t *scb) megaraid_mbox_mksgl(adapter_t *adapter, scb_t *scb)
{ {
struct scatterlist *sgl; struct scatterlist *sgl;
@ -1402,7 +1402,7 @@ megaraid_mbox_mksgl(adapter_t *adapter, scb_t *scb)
* *
* post the command to the controller if mailbox is availble. * post the command to the controller if mailbox is availble.
*/ */
static inline int static int
mbox_post_cmd(adapter_t *adapter, scb_t *scb) mbox_post_cmd(adapter_t *adapter, scb_t *scb)
{ {
mraid_device_t *raid_dev = ADAP2RAIDDEV(adapter); mraid_device_t *raid_dev = ADAP2RAIDDEV(adapter);
@ -2070,7 +2070,7 @@ megaraid_mbox_prepare_epthru(adapter_t *adapter, scb_t *scb,
* *
* Returns: 1 if the interrupt is valid, 0 otherwise * Returns: 1 if the interrupt is valid, 0 otherwise
*/ */
static inline int static int
megaraid_ack_sequence(adapter_t *adapter) megaraid_ack_sequence(adapter_t *adapter)
{ {
mraid_device_t *raid_dev = ADAP2RAIDDEV(adapter); mraid_device_t *raid_dev = ADAP2RAIDDEV(adapter);
@ -2208,7 +2208,7 @@ megaraid_isr(int irq, void *devp, struct pt_regs *regs)
* *
* DMA sync if required. * DMA sync if required.
*/ */
static inline void static void
megaraid_mbox_sync_scb(adapter_t *adapter, scb_t *scb) megaraid_mbox_sync_scb(adapter_t *adapter, scb_t *scb)
{ {
mbox_ccb_t *ccb; mbox_ccb_t *ccb;

View File

@ -81,7 +81,7 @@ static DEFINE_MUTEX(megasas_async_queue_mutex);
* *
* Returns a free command from the pool * Returns a free command from the pool
*/ */
static inline struct megasas_cmd *megasas_get_cmd(struct megasas_instance static struct megasas_cmd *megasas_get_cmd(struct megasas_instance
*instance) *instance)
{ {
unsigned long flags; unsigned long flags;
@ -263,7 +263,7 @@ megasas_issue_blocked_abort_cmd(struct megasas_instance *instance,
* If successful, this function returns the number of SG elements. Otherwise, * If successful, this function returns the number of SG elements. Otherwise,
* it returnes -1. * it returnes -1.
*/ */
static inline int static int
megasas_make_sgl32(struct megasas_instance *instance, struct scsi_cmnd *scp, megasas_make_sgl32(struct megasas_instance *instance, struct scsi_cmnd *scp,
union megasas_sgl *mfi_sgl) union megasas_sgl *mfi_sgl)
{ {
@ -311,7 +311,7 @@ megasas_make_sgl32(struct megasas_instance *instance, struct scsi_cmnd *scp,
* If successful, this function returns the number of SG elements. Otherwise, * If successful, this function returns the number of SG elements. Otherwise,
* it returnes -1. * it returnes -1.
*/ */
static inline int static int
megasas_make_sgl64(struct megasas_instance *instance, struct scsi_cmnd *scp, megasas_make_sgl64(struct megasas_instance *instance, struct scsi_cmnd *scp,
union megasas_sgl *mfi_sgl) union megasas_sgl *mfi_sgl)
{ {
@ -360,7 +360,7 @@ megasas_make_sgl64(struct megasas_instance *instance, struct scsi_cmnd *scp,
* This function prepares CDB commands. These are typcially pass-through * This function prepares CDB commands. These are typcially pass-through
* commands to the devices. * commands to the devices.
*/ */
static inline int static int
megasas_build_dcdb(struct megasas_instance *instance, struct scsi_cmnd *scp, megasas_build_dcdb(struct megasas_instance *instance, struct scsi_cmnd *scp,
struct megasas_cmd *cmd) struct megasas_cmd *cmd)
{ {
@ -441,7 +441,7 @@ megasas_build_dcdb(struct megasas_instance *instance, struct scsi_cmnd *scp,
* *
* Frames (and accompanying SGLs) for regular SCSI IOs use this function. * Frames (and accompanying SGLs) for regular SCSI IOs use this function.
*/ */
static inline int static int
megasas_build_ldio(struct megasas_instance *instance, struct scsi_cmnd *scp, megasas_build_ldio(struct megasas_instance *instance, struct scsi_cmnd *scp,
struct megasas_cmd *cmd) struct megasas_cmd *cmd)
{ {
@ -563,7 +563,7 @@ megasas_build_ldio(struct megasas_instance *instance, struct scsi_cmnd *scp,
* @scp: SCSI command * @scp: SCSI command
* @frame_count: [OUT] Number of frames used to prepare this command * @frame_count: [OUT] Number of frames used to prepare this command
*/ */
static inline struct megasas_cmd *megasas_build_cmd(struct megasas_instance static struct megasas_cmd *megasas_build_cmd(struct megasas_instance
*instance, *instance,
struct scsi_cmnd *scp, struct scsi_cmnd *scp,
int *frame_count) int *frame_count)
@ -914,7 +914,7 @@ megasas_complete_abort(struct megasas_instance *instance,
* @instance: Adapter soft state * @instance: Adapter soft state
* @cmd: Completed command * @cmd: Completed command
*/ */
static inline void static void
megasas_unmap_sgbuf(struct megasas_instance *instance, struct megasas_cmd *cmd) megasas_unmap_sgbuf(struct megasas_instance *instance, struct megasas_cmd *cmd)
{ {
dma_addr_t buf_h; dma_addr_t buf_h;
@ -958,7 +958,7 @@ megasas_unmap_sgbuf(struct megasas_instance *instance, struct megasas_cmd *cmd)
* an alternate status (as in the case of aborted * an alternate status (as in the case of aborted
* commands) * commands)
*/ */
static inline void static void
megasas_complete_cmd(struct megasas_instance *instance, struct megasas_cmd *cmd, megasas_complete_cmd(struct megasas_instance *instance, struct megasas_cmd *cmd,
u8 alt_status) u8 alt_status)
{ {
@ -1105,7 +1105,7 @@ megasas_complete_cmd(struct megasas_instance *instance, struct megasas_cmd *cmd,
* SCSI mid-layer instead of the status * SCSI mid-layer instead of the status
* returned by the FW * returned by the FW
*/ */
static inline int static int
megasas_deplete_reply_queue(struct megasas_instance *instance, u8 alt_status) megasas_deplete_reply_queue(struct megasas_instance *instance, u8 alt_status)
{ {
u32 status; u32 status;

View File

@ -151,7 +151,7 @@ static inline struct scsi_cd *scsi_cd_get(struct gendisk *disk)
return cd; return cd;
} }
static inline void scsi_cd_put(struct scsi_cd *cd) static void scsi_cd_put(struct scsi_cd *cd)
{ {
struct scsi_device *sdev = cd->device; struct scsi_device *sdev = cd->device;

View File

@ -207,7 +207,7 @@ static inline void usbatm_pop(struct atm_vcc *vcc, struct sk_buff *skb)
** urbs ** ** urbs **
************/ ************/
static inline struct urb *usbatm_pop_urb(struct usbatm_channel *channel) static struct urb *usbatm_pop_urb(struct usbatm_channel *channel)
{ {
struct urb *urb; struct urb *urb;
@ -224,7 +224,7 @@ static inline struct urb *usbatm_pop_urb(struct usbatm_channel *channel)
return urb; return urb;
} }
static inline int usbatm_submit_urb(struct urb *urb) static int usbatm_submit_urb(struct urb *urb)
{ {
struct usbatm_channel *channel = urb->context; struct usbatm_channel *channel = urb->context;
int ret; int ret;

View File

@ -968,7 +968,7 @@ static inline int maven_compute_timming(struct maven_data* md,
return 0; return 0;
} }
static inline int maven_program_timming(struct maven_data* md, static int maven_program_timming(struct maven_data* md,
const struct mavenregs* m) { const struct mavenregs* m) {
struct i2c_client* c = md->client; struct i2c_client* c = md->client;

View File

@ -56,7 +56,7 @@ static inline int buf_check_overflow(struct cbuf *buf)
return buf->p > buf->ep; return buf->p > buf->ep;
} }
static inline int buf_check_size(struct cbuf *buf, int len) static int buf_check_size(struct cbuf *buf, int len)
{ {
if (buf->p + len > buf->ep) { if (buf->p + len > buf->ep) {
if (buf->p < buf->ep) { if (buf->p < buf->ep) {
@ -72,7 +72,7 @@ static inline int buf_check_size(struct cbuf *buf, int len)
return 1; return 1;
} }
static inline void *buf_alloc(struct cbuf *buf, int len) static void *buf_alloc(struct cbuf *buf, int len)
{ {
void *ret = NULL; void *ret = NULL;
@ -84,7 +84,7 @@ static inline void *buf_alloc(struct cbuf *buf, int len)
return ret; return ret;
} }
static inline void buf_put_int8(struct cbuf *buf, u8 val) static void buf_put_int8(struct cbuf *buf, u8 val)
{ {
if (buf_check_size(buf, 1)) { if (buf_check_size(buf, 1)) {
buf->p[0] = val; buf->p[0] = val;
@ -92,7 +92,7 @@ static inline void buf_put_int8(struct cbuf *buf, u8 val)
} }
} }
static inline void buf_put_int16(struct cbuf *buf, u16 val) static void buf_put_int16(struct cbuf *buf, u16 val)
{ {
if (buf_check_size(buf, 2)) { if (buf_check_size(buf, 2)) {
*(__le16 *) buf->p = cpu_to_le16(val); *(__le16 *) buf->p = cpu_to_le16(val);
@ -100,7 +100,7 @@ static inline void buf_put_int16(struct cbuf *buf, u16 val)
} }
} }
static inline void buf_put_int32(struct cbuf *buf, u32 val) static void buf_put_int32(struct cbuf *buf, u32 val)
{ {
if (buf_check_size(buf, 4)) { if (buf_check_size(buf, 4)) {
*(__le32 *)buf->p = cpu_to_le32(val); *(__le32 *)buf->p = cpu_to_le32(val);
@ -108,7 +108,7 @@ static inline void buf_put_int32(struct cbuf *buf, u32 val)
} }
} }
static inline void buf_put_int64(struct cbuf *buf, u64 val) static void buf_put_int64(struct cbuf *buf, u64 val)
{ {
if (buf_check_size(buf, 8)) { if (buf_check_size(buf, 8)) {
*(__le64 *)buf->p = cpu_to_le64(val); *(__le64 *)buf->p = cpu_to_le64(val);
@ -116,7 +116,7 @@ static inline void buf_put_int64(struct cbuf *buf, u64 val)
} }
} }
static inline void buf_put_stringn(struct cbuf *buf, const char *s, u16 slen) static void buf_put_stringn(struct cbuf *buf, const char *s, u16 slen)
{ {
if (buf_check_size(buf, slen + 2)) { if (buf_check_size(buf, slen + 2)) {
buf_put_int16(buf, slen); buf_put_int16(buf, slen);
@ -130,7 +130,7 @@ static inline void buf_put_string(struct cbuf *buf, const char *s)
buf_put_stringn(buf, s, strlen(s)); buf_put_stringn(buf, s, strlen(s));
} }
static inline u8 buf_get_int8(struct cbuf *buf) static u8 buf_get_int8(struct cbuf *buf)
{ {
u8 ret = 0; u8 ret = 0;
@ -142,7 +142,7 @@ static inline u8 buf_get_int8(struct cbuf *buf)
return ret; return ret;
} }
static inline u16 buf_get_int16(struct cbuf *buf) static u16 buf_get_int16(struct cbuf *buf)
{ {
u16 ret = 0; u16 ret = 0;
@ -154,7 +154,7 @@ static inline u16 buf_get_int16(struct cbuf *buf)
return ret; return ret;
} }
static inline u32 buf_get_int32(struct cbuf *buf) static u32 buf_get_int32(struct cbuf *buf)
{ {
u32 ret = 0; u32 ret = 0;
@ -166,7 +166,7 @@ static inline u32 buf_get_int32(struct cbuf *buf)
return ret; return ret;
} }
static inline u64 buf_get_int64(struct cbuf *buf) static u64 buf_get_int64(struct cbuf *buf)
{ {
u64 ret = 0; u64 ret = 0;
@ -178,7 +178,7 @@ static inline u64 buf_get_int64(struct cbuf *buf)
return ret; return ret;
} }
static inline void buf_get_str(struct cbuf *buf, struct v9fs_str *vstr) static void buf_get_str(struct cbuf *buf, struct v9fs_str *vstr)
{ {
vstr->len = buf_get_int16(buf); vstr->len = buf_get_int16(buf);
if (!buf_check_overflow(buf) && buf_check_size(buf, vstr->len)) { if (!buf_check_overflow(buf) && buf_check_size(buf, vstr->len)) {
@ -190,7 +190,7 @@ static inline void buf_get_str(struct cbuf *buf, struct v9fs_str *vstr)
} }
} }
static inline void buf_get_qid(struct cbuf *bufp, struct v9fs_qid *qid) static void buf_get_qid(struct cbuf *bufp, struct v9fs_qid *qid)
{ {
qid->type = buf_get_int8(bufp); qid->type = buf_get_int8(bufp);
qid->version = buf_get_int32(bufp); qid->version = buf_get_int32(bufp);
@ -254,7 +254,7 @@ static int v9fs_size_wstat(struct v9fs_wstat *wstat, int extended)
* *
*/ */
static inline void static void
buf_get_stat(struct cbuf *bufp, struct v9fs_stat *stat, int extended) buf_get_stat(struct cbuf *bufp, struct v9fs_stat *stat, int extended)
{ {
stat->size = buf_get_int16(bufp); stat->size = buf_get_int16(bufp);
@ -427,7 +427,7 @@ static inline void v9fs_put_int64(struct cbuf *bufp, u64 val, u64 * p)
buf_put_int64(bufp, val); buf_put_int64(bufp, val);
} }
static inline void static void
v9fs_put_str(struct cbuf *bufp, char *data, struct v9fs_str *str) v9fs_put_str(struct cbuf *bufp, char *data, struct v9fs_str *str)
{ {
if (data) { if (data) {
@ -441,7 +441,7 @@ v9fs_put_str(struct cbuf *bufp, char *data, struct v9fs_str *str)
buf_put_stringn(bufp, data, str->len); buf_put_stringn(bufp, data, str->len);
} }
static inline int static int
v9fs_put_user_data(struct cbuf *bufp, const char __user * data, int count, v9fs_put_user_data(struct cbuf *bufp, const char __user * data, int count,
unsigned char **pdata) unsigned char **pdata)
{ {

View File

@ -1218,7 +1218,7 @@ static int writenote(struct memelfnote *men, struct file *file)
if (!dump_seek(file, (off))) \ if (!dump_seek(file, (off))) \
goto end_coredump; goto end_coredump;
static inline void fill_elf_header(struct elfhdr *elf, int segs) static void fill_elf_header(struct elfhdr *elf, int segs)
{ {
memcpy(elf->e_ident, ELFMAG, SELFMAG); memcpy(elf->e_ident, ELFMAG, SELFMAG);
elf->e_ident[EI_CLASS] = ELF_CLASS; elf->e_ident[EI_CLASS] = ELF_CLASS;
@ -1243,7 +1243,7 @@ static inline void fill_elf_header(struct elfhdr *elf, int segs)
return; return;
} }
static inline void fill_elf_note_phdr(struct elf_phdr *phdr, int sz, off_t offset) static void fill_elf_note_phdr(struct elf_phdr *phdr, int sz, off_t offset)
{ {
phdr->p_type = PT_NOTE; phdr->p_type = PT_NOTE;
phdr->p_offset = offset; phdr->p_offset = offset;

View File

@ -264,7 +264,7 @@ static int unquote(char *from)
return p - from; return p - from;
} }
static inline char * check_special_flags (char * sfs, Node * e) static char * check_special_flags (char * sfs, Node * e)
{ {
char * p = sfs; char * p = sfs;
int cont = 1; int cont = 1;

View File

@ -123,7 +123,7 @@ static void bio_fs_destructor(struct bio *bio)
bio_free(bio, fs_bio_set); bio_free(bio, fs_bio_set);
} }
inline void bio_init(struct bio *bio) void bio_init(struct bio *bio)
{ {
bio->bi_next = NULL; bio->bi_next = NULL;
bio->bi_bdev = NULL; bio->bi_bdev = NULL;
@ -253,7 +253,7 @@ inline int bio_hw_segments(request_queue_t *q, struct bio *bio)
* the actual data it points to. Reference count of returned * the actual data it points to. Reference count of returned
* bio will be one. * bio will be one.
*/ */
inline void __bio_clone(struct bio *bio, struct bio *bio_src) void __bio_clone(struct bio *bio, struct bio *bio_src)
{ {
request_queue_t *q = bdev_get_queue(bio_src->bi_bdev); request_queue_t *q = bdev_get_queue(bio_src->bi_bdev);

View File

@ -1165,7 +1165,7 @@ failed:
* some of those buffers may be aliases of filesystem data. * some of those buffers may be aliases of filesystem data.
* grow_dev_page() will go BUG() if this happens. * grow_dev_page() will go BUG() if this happens.
*/ */
static inline int static int
grow_buffers(struct block_device *bdev, sector_t block, int size) grow_buffers(struct block_device *bdev, sector_t block, int size)
{ {
struct page *page; struct page *page;
@ -1391,7 +1391,7 @@ static void bh_lru_install(struct buffer_head *bh)
/* /*
* Look up the bh in this cpu's LRU. If it's there, move it to the head. * Look up the bh in this cpu's LRU. If it's there, move it to the head.
*/ */
static inline struct buffer_head * static struct buffer_head *
lookup_bh_lru(struct block_device *bdev, sector_t block, int size) lookup_bh_lru(struct block_device *bdev, sector_t block, int size)
{ {
struct buffer_head *ret = NULL; struct buffer_head *ret = NULL;
@ -1541,7 +1541,7 @@ EXPORT_SYMBOL(set_bh_page);
/* /*
* Called when truncating a buffer on a page completely. * Called when truncating a buffer on a page completely.
*/ */
static inline void discard_buffer(struct buffer_head * bh) static void discard_buffer(struct buffer_head * bh)
{ {
lock_buffer(bh); lock_buffer(bh);
clear_buffer_dirty(bh); clear_buffer_dirty(bh);

View File

@ -1537,7 +1537,7 @@ out_ret:
* Ooo, nasty. We need here to frob 32-bit unsigned longs to * Ooo, nasty. We need here to frob 32-bit unsigned longs to
* 64-bit unsigned longs. * 64-bit unsigned longs.
*/ */
static inline static
int compat_get_fd_set(unsigned long nr, compat_ulong_t __user *ufdset, int compat_get_fd_set(unsigned long nr, compat_ulong_t __user *ufdset,
unsigned long *fdset) unsigned long *fdset)
{ {
@ -1570,7 +1570,7 @@ int compat_get_fd_set(unsigned long nr, compat_ulong_t __user *ufdset,
return 0; return 0;
} }
static inline static
void compat_set_fd_set(unsigned long nr, compat_ulong_t __user *ufdset, void compat_set_fd_set(unsigned long nr, compat_ulong_t __user *ufdset,
unsigned long *fdset) unsigned long *fdset)
{ {

View File

@ -94,7 +94,7 @@ static void d_free(struct dentry *dentry)
* d_iput() operation if defined. * d_iput() operation if defined.
* Called with dcache_lock and per dentry lock held, drops both. * Called with dcache_lock and per dentry lock held, drops both.
*/ */
static inline void dentry_iput(struct dentry * dentry) static void dentry_iput(struct dentry * dentry)
{ {
struct inode *inode = dentry->d_inode; struct inode *inode = dentry->d_inode;
if (inode) { if (inode) {

View File

@ -575,7 +575,7 @@ static int exec_mmap(struct mm_struct *mm)
* disturbing other processes. (Other processes might share the signal * disturbing other processes. (Other processes might share the signal
* table via the CLONE_SIGHAND option to clone().) * table via the CLONE_SIGHAND option to clone().)
*/ */
static inline int de_thread(struct task_struct *tsk) static int de_thread(struct task_struct *tsk)
{ {
struct signal_struct *sig = tsk->signal; struct signal_struct *sig = tsk->signal;
struct sighand_struct *newsighand, *oldsighand = tsk->sighand; struct sighand_struct *newsighand, *oldsighand = tsk->sighand;
@ -780,7 +780,7 @@ no_thread_group:
* so that a new one can be started * so that a new one can be started
*/ */
static inline void flush_old_files(struct files_struct * files) static void flush_old_files(struct files_struct * files)
{ {
long j = -1; long j = -1;
struct fdtable *fdt; struct fdtable *fdt;
@ -964,7 +964,7 @@ int prepare_binprm(struct linux_binprm *bprm)
EXPORT_SYMBOL(prepare_binprm); EXPORT_SYMBOL(prepare_binprm);
static inline int unsafe_exec(struct task_struct *p) static int unsafe_exec(struct task_struct *p)
{ {
int unsafe = 0; int unsafe = 0;
if (p->ptrace & PT_PTRACED) { if (p->ptrace & PT_PTRACED) {

View File

@ -36,7 +36,7 @@ void fastcall set_close_on_exec(unsigned int fd, int flag)
spin_unlock(&files->file_lock); spin_unlock(&files->file_lock);
} }
static inline int get_close_on_exec(unsigned int fd) static int get_close_on_exec(unsigned int fd)
{ {
struct files_struct *files = current->files; struct files_struct *files = current->files;
struct fdtable *fdt; struct fdtable *fdt;

View File

@ -47,7 +47,7 @@ next_inode(int *i, struct jffs2_inode_cache *ic, struct jffs2_sb_info *c)
ic = next_inode(&i, ic, (c))) ic = next_inode(&i, ic, (c)))
static inline void jffs2_build_inode_pass1(struct jffs2_sb_info *c, static void jffs2_build_inode_pass1(struct jffs2_sb_info *c,
struct jffs2_inode_cache *ic) struct jffs2_inode_cache *ic)
{ {
struct jffs2_full_dirent *fd; struct jffs2_full_dirent *fd;

View File

@ -134,7 +134,7 @@ static void jffs2_fragtree_insert(struct jffs2_node_frag *newfrag, struct jffs2_
/* /*
* Allocate and initializes a new fragment. * Allocate and initializes a new fragment.
*/ */
static inline struct jffs2_node_frag * new_fragment(struct jffs2_full_dnode *fn, uint32_t ofs, uint32_t size) static struct jffs2_node_frag * new_fragment(struct jffs2_full_dnode *fn, uint32_t ofs, uint32_t size)
{ {
struct jffs2_node_frag *newfrag; struct jffs2_node_frag *newfrag;
@ -513,7 +513,7 @@ free_out:
* *
* Checks the node if we are in the checking stage. * Checks the node if we are in the checking stage.
*/ */
static inline int check_node(struct jffs2_sb_info *c, struct jffs2_inode_info *f, struct jffs2_tmp_dnode_info *tn) static int check_node(struct jffs2_sb_info *c, struct jffs2_inode_info *f, struct jffs2_tmp_dnode_info *tn)
{ {
int ret; int ret;

View File

@ -44,7 +44,7 @@ loff_t_to_s32(loff_t offset)
/* /*
* XDR functions for basic NLM types * XDR functions for basic NLM types
*/ */
static inline u32 *nlm_decode_cookie(u32 *p, struct nlm_cookie *c) static u32 *nlm_decode_cookie(u32 *p, struct nlm_cookie *c)
{ {
unsigned int len; unsigned int len;
@ -79,7 +79,7 @@ nlm_encode_cookie(u32 *p, struct nlm_cookie *c)
return p; return p;
} }
static inline u32 * static u32 *
nlm_decode_fh(u32 *p, struct nfs_fh *f) nlm_decode_fh(u32 *p, struct nfs_fh *f)
{ {
unsigned int len; unsigned int len;
@ -119,7 +119,7 @@ nlm_encode_oh(u32 *p, struct xdr_netobj *oh)
return xdr_encode_netobj(p, oh); return xdr_encode_netobj(p, oh);
} }
static inline u32 * static u32 *
nlm_decode_lock(u32 *p, struct nlm_lock *lock) nlm_decode_lock(u32 *p, struct nlm_lock *lock)
{ {
struct file_lock *fl = &lock->fl; struct file_lock *fl = &lock->fl;

View File

@ -126,7 +126,7 @@ __mb_cache_entry_is_hashed(struct mb_cache_entry *ce)
} }
static inline void static void
__mb_cache_entry_unhash(struct mb_cache_entry *ce) __mb_cache_entry_unhash(struct mb_cache_entry *ce)
{ {
int n; int n;
@ -139,7 +139,7 @@ __mb_cache_entry_unhash(struct mb_cache_entry *ce)
} }
static inline void static void
__mb_cache_entry_forget(struct mb_cache_entry *ce, gfp_t gfp_mask) __mb_cache_entry_forget(struct mb_cache_entry *ce, gfp_t gfp_mask)
{ {
struct mb_cache *cache = ce->e_cache; struct mb_cache *cache = ce->e_cache;
@ -158,7 +158,7 @@ __mb_cache_entry_forget(struct mb_cache_entry *ce, gfp_t gfp_mask)
} }
static inline void static void
__mb_cache_entry_release_unlock(struct mb_cache_entry *ce) __mb_cache_entry_release_unlock(struct mb_cache_entry *ce)
{ {
/* Wake up all processes queuing for this cache entry. */ /* Wake up all processes queuing for this cache entry. */

View File

@ -113,7 +113,7 @@
* POSIX.1 2.4: an empty pathname is invalid (ENOENT). * POSIX.1 2.4: an empty pathname is invalid (ENOENT).
* PATH_MAX includes the nul terminator --RR. * PATH_MAX includes the nul terminator --RR.
*/ */
static inline int do_getname(const char __user *filename, char *page) static int do_getname(const char __user *filename, char *page)
{ {
int retval; int retval;
unsigned long len = PATH_MAX; unsigned long len = PATH_MAX;
@ -396,7 +396,7 @@ static struct dentry * cached_lookup(struct dentry * parent, struct qstr * name,
* short-cut DAC fails, then call permission() to do more * short-cut DAC fails, then call permission() to do more
* complete permission check. * complete permission check.
*/ */
static inline int exec_permission_lite(struct inode *inode, static int exec_permission_lite(struct inode *inode,
struct nameidata *nd) struct nameidata *nd)
{ {
umode_t mode = inode->i_mode; umode_t mode = inode->i_mode;
@ -1294,7 +1294,7 @@ static inline int check_sticky(struct inode *dir, struct inode *inode)
* 10. We don't allow removal of NFS sillyrenamed files; it's handled by * 10. We don't allow removal of NFS sillyrenamed files; it's handled by
* nfs_async_unlink(). * nfs_async_unlink().
*/ */
static inline int may_delete(struct inode *dir,struct dentry *victim,int isdir) static int may_delete(struct inode *dir,struct dentry *victim,int isdir)
{ {
int error; int error;
@ -2315,7 +2315,7 @@ int vfs_rename(struct inode *old_dir, struct dentry *old_dentry,
return error; return error;
} }
static inline int do_rename(const char * oldname, const char * newname) static int do_rename(const char * oldname, const char * newname)
{ {
int error = 0; int error = 0;
struct dentry * old_dir, * new_dir; struct dentry * old_dir, * new_dir;

View File

@ -37,7 +37,7 @@ static u32 nfs_ftypes[] = {
/* /*
* XDR functions for basic NFS types * XDR functions for basic NFS types
*/ */
static inline u32 * static u32 *
decode_fh(u32 *p, struct svc_fh *fhp) decode_fh(u32 *p, struct svc_fh *fhp)
{ {
fh_init(fhp, NFS_FHSIZE); fh_init(fhp, NFS_FHSIZE);
@ -151,7 +151,7 @@ decode_sattr(u32 *p, struct iattr *iap)
return p; return p;
} }
static inline u32 * static u32 *
encode_fattr(struct svc_rqst *rqstp, u32 *p, struct svc_fh *fhp, encode_fattr(struct svc_rqst *rqstp, u32 *p, struct svc_fh *fhp,
struct kstat *stat) struct kstat *stat)
{ {

View File

@ -50,7 +50,7 @@ void pipe_wait(struct inode * inode)
mutex_lock(PIPE_MUTEX(*inode)); mutex_lock(PIPE_MUTEX(*inode));
} }
static inline int static int
pipe_iov_copy_from_user(void *to, struct iovec *iov, unsigned long len) pipe_iov_copy_from_user(void *to, struct iovec *iov, unsigned long len)
{ {
unsigned long copy; unsigned long copy;
@ -70,7 +70,7 @@ pipe_iov_copy_from_user(void *to, struct iovec *iov, unsigned long len)
return 0; return 0;
} }
static inline int static int
pipe_iov_copy_to_user(struct iovec *iov, const void *from, unsigned long len) pipe_iov_copy_to_user(struct iovec *iov, const void *from, unsigned long len)
{ {
unsigned long copy; unsigned long copy;

View File

@ -1554,7 +1554,7 @@ struct ctr_struct {
* when reading out p->cpuset, as we don't really care if it changes * when reading out p->cpuset, as we don't really care if it changes
* on the next cycle, and we are not going to try to dereference it. * on the next cycle, and we are not going to try to dereference it.
*/ */
static inline int pid_array_load(pid_t *pidarray, int npids, struct cpuset *cs) static int pid_array_load(pid_t *pidarray, int npids, struct cpuset *cs)
{ {
int n = 0; int n = 0;
struct task_struct *g, *p; struct task_struct *g, *p;

View File

@ -193,7 +193,7 @@ int is_orphaned_pgrp(int pgrp)
return retval; return retval;
} }
static inline int has_stopped_jobs(int pgrp) static int has_stopped_jobs(int pgrp)
{ {
int retval = 0; int retval = 0;
struct task_struct *p; struct task_struct *p;
@ -230,7 +230,7 @@ static inline int has_stopped_jobs(int pgrp)
* *
* NOTE that reparent_to_init() gives the caller full capabilities. * NOTE that reparent_to_init() gives the caller full capabilities.
*/ */
static inline void reparent_to_init(void) static void reparent_to_init(void)
{ {
write_lock_irq(&tasklist_lock); write_lock_irq(&tasklist_lock);
@ -369,7 +369,7 @@ void daemonize(const char *name, ...)
EXPORT_SYMBOL(daemonize); EXPORT_SYMBOL(daemonize);
static inline void close_files(struct files_struct * files) static void close_files(struct files_struct * files)
{ {
int i, j; int i, j;
struct fdtable *fdt; struct fdtable *fdt;
@ -543,7 +543,7 @@ static inline void choose_new_parent(task_t *p, task_t *reaper, task_t *child_re
p->real_parent = reaper; p->real_parent = reaper;
} }
static inline void reparent_thread(task_t *p, task_t *father, int traced) static void reparent_thread(task_t *p, task_t *father, int traced)
{ {
/* We don't want people slaying init. */ /* We don't want people slaying init. */
if (p->exit_signal != -1) if (p->exit_signal != -1)
@ -607,7 +607,7 @@ static inline void reparent_thread(task_t *p, task_t *father, int traced)
* group, and if no such member exists, give it to * group, and if no such member exists, give it to
* the global child reaper process (ie "init") * the global child reaper process (ie "init")
*/ */
static inline void forget_original_parent(struct task_struct * father, static void forget_original_parent(struct task_struct * father,
struct list_head *to_release) struct list_head *to_release)
{ {
struct task_struct *p, *reaper = father; struct task_struct *p, *reaper = father;

View File

@ -192,7 +192,7 @@ static inline int common_clock_set(const clockid_t which_clock,
return do_sys_settimeofday(tp, NULL); return do_sys_settimeofday(tp, NULL);
} }
static inline int common_timer_create(struct k_itimer *new_timer) static int common_timer_create(struct k_itimer *new_timer)
{ {
hrtimer_init(&new_timer->it.real.timer, new_timer->it_clock); hrtimer_init(&new_timer->it.real.timer, new_timer->it_clock);
new_timer->it.real.timer.data = new_timer; new_timer->it.real.timer.data = new_timer;
@ -361,7 +361,7 @@ static int posix_timer_fn(void *data)
return ret; return ret;
} }
static inline struct task_struct * good_sigevent(sigevent_t * event) static struct task_struct * good_sigevent(sigevent_t * event)
{ {
struct task_struct *rtn = current->group_leader; struct task_struct *rtn = current->group_leader;
@ -687,7 +687,7 @@ sys_timer_getoverrun(timer_t timer_id)
/* Set a POSIX.1b interval timer. */ /* Set a POSIX.1b interval timer. */
/* timr->it_lock is taken. */ /* timr->it_lock is taken. */
static inline int static int
common_timer_set(struct k_itimer *timr, int flags, common_timer_set(struct k_itimer *timr, int flags,
struct itimerspec *new_setting, struct itimerspec *old_setting) struct itimerspec *new_setting, struct itimerspec *old_setting)
{ {
@ -829,7 +829,7 @@ retry_delete:
/* /*
* return timer owned by the process, used by exit_itimers * return timer owned by the process, used by exit_itimers
*/ */
static inline void itimer_delete(struct k_itimer *timer) static void itimer_delete(struct k_itimer *timer)
{ {
unsigned long flags; unsigned long flags;

View File

@ -521,7 +521,7 @@ static inline void sched_info_dequeued(task_t *t)
* long it was waiting to run. We also note when it began so that we * long it was waiting to run. We also note when it began so that we
* can keep stats on how long its timeslice is. * can keep stats on how long its timeslice is.
*/ */
static inline void sched_info_arrive(task_t *t) static void sched_info_arrive(task_t *t)
{ {
unsigned long now = jiffies, diff = 0; unsigned long now = jiffies, diff = 0;
struct runqueue *rq = task_rq(t); struct runqueue *rq = task_rq(t);
@ -1007,7 +1007,7 @@ void kick_process(task_t *p)
* We want to under-estimate the load of migration sources, to * We want to under-estimate the load of migration sources, to
* balance conservatively. * balance conservatively.
*/ */
static inline unsigned long __source_load(int cpu, int type, enum idle_type idle) static unsigned long __source_load(int cpu, int type, enum idle_type idle)
{ {
runqueue_t *rq = cpu_rq(cpu); runqueue_t *rq = cpu_rq(cpu);
unsigned long running = rq->nr_running; unsigned long running = rq->nr_running;
@ -1870,7 +1870,7 @@ void sched_exec(void)
* pull_task - move a task from a remote runqueue to the local runqueue. * pull_task - move a task from a remote runqueue to the local runqueue.
* Both runqueues must be locked. * Both runqueues must be locked.
*/ */
static inline static
void pull_task(runqueue_t *src_rq, prio_array_t *src_array, task_t *p, void pull_task(runqueue_t *src_rq, prio_array_t *src_array, task_t *p,
runqueue_t *this_rq, prio_array_t *this_array, int this_cpu) runqueue_t *this_rq, prio_array_t *this_array, int this_cpu)
{ {
@ -1892,7 +1892,7 @@ void pull_task(runqueue_t *src_rq, prio_array_t *src_array, task_t *p,
/* /*
* can_migrate_task - may task p from runqueue rq be migrated to this_cpu? * can_migrate_task - may task p from runqueue rq be migrated to this_cpu?
*/ */
static inline static
int can_migrate_task(task_t *p, runqueue_t *rq, int this_cpu, int can_migrate_task(task_t *p, runqueue_t *rq, int this_cpu,
struct sched_domain *sd, enum idle_type idle, struct sched_domain *sd, enum idle_type idle,
int *all_pinned) int *all_pinned)
@ -2378,7 +2378,7 @@ out_balanced:
* idle_balance is called by schedule() if this_cpu is about to become * idle_balance is called by schedule() if this_cpu is about to become
* idle. Attempts to pull tasks from other CPUs. * idle. Attempts to pull tasks from other CPUs.
*/ */
static inline void idle_balance(int this_cpu, runqueue_t *this_rq) static void idle_balance(int this_cpu, runqueue_t *this_rq)
{ {
struct sched_domain *sd; struct sched_domain *sd;
@ -2762,7 +2762,7 @@ static inline void wakeup_busy_runqueue(runqueue_t *rq)
resched_task(rq->idle); resched_task(rq->idle);
} }
static inline void wake_sleeping_dependent(int this_cpu, runqueue_t *this_rq) static void wake_sleeping_dependent(int this_cpu, runqueue_t *this_rq)
{ {
struct sched_domain *tmp, *sd = NULL; struct sched_domain *tmp, *sd = NULL;
cpumask_t sibling_map; cpumask_t sibling_map;
@ -2816,7 +2816,7 @@ static inline unsigned long smt_slice(task_t *p, struct sched_domain *sd)
return p->time_slice * (100 - sd->per_cpu_gain) / 100; return p->time_slice * (100 - sd->per_cpu_gain) / 100;
} }
static inline int dependent_sleeper(int this_cpu, runqueue_t *this_rq) static int dependent_sleeper(int this_cpu, runqueue_t *this_rq)
{ {
struct sched_domain *tmp, *sd = NULL; struct sched_domain *tmp, *sd = NULL;
cpumask_t sibling_map; cpumask_t sibling_map;
@ -6008,7 +6008,7 @@ next_sg:
* Detach sched domains from a group of cpus specified in cpu_map * Detach sched domains from a group of cpus specified in cpu_map
* These cpus will now be attached to the NULL domain * These cpus will now be attached to the NULL domain
*/ */
static inline void detach_destroy_domains(const cpumask_t *cpu_map) static void detach_destroy_domains(const cpumask_t *cpu_map)
{ {
int i; int i;

View File

@ -476,7 +476,7 @@ unblock_all_signals(void)
spin_unlock_irqrestore(&current->sighand->siglock, flags); spin_unlock_irqrestore(&current->sighand->siglock, flags);
} }
static inline int collect_signal(int sig, struct sigpending *list, siginfo_t *info) static int collect_signal(int sig, struct sigpending *list, siginfo_t *info)
{ {
struct sigqueue *q, *first = NULL; struct sigqueue *q, *first = NULL;
int still_pending = 0; int still_pending = 0;
@ -1881,7 +1881,7 @@ do_signal_stop(int signr)
* We return zero if we still hold the siglock and should look * We return zero if we still hold the siglock and should look
* for another signal without checking group_stop_count again. * for another signal without checking group_stop_count again.
*/ */
static inline int handle_group_stop(void) static int handle_group_stop(void)
{ {
int stop_count; int stop_count;

View File

@ -147,7 +147,7 @@ int fastcall queue_delayed_work(struct workqueue_struct *wq,
return ret; return ret;
} }
static inline void run_workqueue(struct cpu_workqueue_struct *cwq) static void run_workqueue(struct cpu_workqueue_struct *cwq)
{ {
unsigned long flags; unsigned long flags;

View File

@ -62,7 +62,7 @@ MODULE_DESCRIPTION(DRV_DESCRIPTION);
MODULE_AUTHOR(DRV_COPYRIGHT); MODULE_AUTHOR(DRV_COPYRIGHT);
MODULE_LICENSE("GPL"); MODULE_LICENSE("GPL");
static inline int ieee80211_networks_allocate(struct ieee80211_device *ieee) static int ieee80211_networks_allocate(struct ieee80211_device *ieee)
{ {
if (ieee->networks) if (ieee->networks)
return 0; return 0;
@ -90,7 +90,7 @@ static inline void ieee80211_networks_free(struct ieee80211_device *ieee)
ieee->networks = NULL; ieee->networks = NULL;
} }
static inline void ieee80211_networks_initialize(struct ieee80211_device *ieee) static void ieee80211_networks_initialize(struct ieee80211_device *ieee)
{ {
int i; int i;

View File

@ -35,7 +35,7 @@
#include <net/ieee80211.h> #include <net/ieee80211.h>
static inline void ieee80211_monitor_rx(struct ieee80211_device *ieee, static void ieee80211_monitor_rx(struct ieee80211_device *ieee,
struct sk_buff *skb, struct sk_buff *skb,
struct ieee80211_rx_stats *rx_stats) struct ieee80211_rx_stats *rx_stats)
{ {
@ -165,7 +165,7 @@ static int ieee80211_frag_cache_invalidate(struct ieee80211_device *ieee,
* Responsible for handling management control frames * Responsible for handling management control frames
* *
* Called by ieee80211_rx */ * Called by ieee80211_rx */
static inline int static int
ieee80211_rx_frame_mgmt(struct ieee80211_device *ieee, struct sk_buff *skb, ieee80211_rx_frame_mgmt(struct ieee80211_device *ieee, struct sk_buff *skb,
struct ieee80211_rx_stats *rx_stats, u16 type, struct ieee80211_rx_stats *rx_stats, u16 type,
u16 stype) u16 stype)
@ -266,7 +266,7 @@ static int ieee80211_is_eapol_frame(struct ieee80211_device *ieee,
} }
/* Called only as a tasklet (software IRQ), by ieee80211_rx */ /* Called only as a tasklet (software IRQ), by ieee80211_rx */
static inline int static int
ieee80211_rx_frame_decrypt(struct ieee80211_device *ieee, struct sk_buff *skb, ieee80211_rx_frame_decrypt(struct ieee80211_device *ieee, struct sk_buff *skb,
struct ieee80211_crypt_data *crypt) struct ieee80211_crypt_data *crypt)
{ {
@ -297,7 +297,7 @@ ieee80211_rx_frame_decrypt(struct ieee80211_device *ieee, struct sk_buff *skb,
} }
/* Called only as a tasklet (software IRQ), by ieee80211_rx */ /* Called only as a tasklet (software IRQ), by ieee80211_rx */
static inline int static int
ieee80211_rx_frame_decrypt_msdu(struct ieee80211_device *ieee, ieee80211_rx_frame_decrypt_msdu(struct ieee80211_device *ieee,
struct sk_buff *skb, int keyidx, struct sk_buff *skb, int keyidx,
struct ieee80211_crypt_data *crypt) struct ieee80211_crypt_data *crypt)
@ -1156,7 +1156,7 @@ static int ieee80211_handle_assoc_resp(struct ieee80211_device *ieee, struct iee
/***************************************************/ /***************************************************/
static inline int ieee80211_network_init(struct ieee80211_device *ieee, struct ieee80211_probe_response static int ieee80211_network_init(struct ieee80211_device *ieee, struct ieee80211_probe_response
*beacon, *beacon,
struct ieee80211_network *network, struct ieee80211_network *network,
struct ieee80211_rx_stats *stats) struct ieee80211_rx_stats *stats)
@ -1235,7 +1235,7 @@ static inline int is_same_network(struct ieee80211_network *src,
!memcmp(src->ssid, dst->ssid, src->ssid_len)); !memcmp(src->ssid, dst->ssid, src->ssid_len));
} }
static inline void update_network(struct ieee80211_network *dst, static void update_network(struct ieee80211_network *dst,
struct ieee80211_network *src) struct ieee80211_network *src)
{ {
int qos_active; int qos_active;
@ -1294,7 +1294,7 @@ static inline int is_beacon(int fc)
return (WLAN_FC_GET_STYPE(le16_to_cpu(fc)) == IEEE80211_STYPE_BEACON); return (WLAN_FC_GET_STYPE(le16_to_cpu(fc)) == IEEE80211_STYPE_BEACON);
} }
static inline void ieee80211_process_probe_response(struct ieee80211_device static void ieee80211_process_probe_response(struct ieee80211_device
*ieee, struct *ieee, struct
ieee80211_probe_response ieee80211_probe_response
*beacon, struct ieee80211_rx_stats *beacon, struct ieee80211_rx_stats

View File

@ -127,7 +127,7 @@ payload of each frame is reduced to 492 bytes.
static u8 P802_1H_OUI[P80211_OUI_LEN] = { 0x00, 0x00, 0xf8 }; static u8 P802_1H_OUI[P80211_OUI_LEN] = { 0x00, 0x00, 0xf8 };
static u8 RFC1042_OUI[P80211_OUI_LEN] = { 0x00, 0x00, 0x00 }; static u8 RFC1042_OUI[P80211_OUI_LEN] = { 0x00, 0x00, 0x00 };
static inline int ieee80211_copy_snap(u8 * data, u16 h_proto) static int ieee80211_copy_snap(u8 * data, u16 h_proto)
{ {
struct ieee80211_snap_hdr *snap; struct ieee80211_snap_hdr *snap;
u8 *oui; u8 *oui;
@ -150,7 +150,7 @@ static inline int ieee80211_copy_snap(u8 * data, u16 h_proto)
return SNAP_SIZE + sizeof(u16); return SNAP_SIZE + sizeof(u16);
} }
static inline int ieee80211_encrypt_fragment(struct ieee80211_device *ieee, static int ieee80211_encrypt_fragment(struct ieee80211_device *ieee,
struct sk_buff *frag, int hdr_len) struct sk_buff *frag, int hdr_len)
{ {
struct ieee80211_crypt_data *crypt = ieee->crypt[ieee->tx_keyidx]; struct ieee80211_crypt_data *crypt = ieee->crypt[ieee->tx_keyidx];

View File

@ -42,7 +42,7 @@ static const char *ieee80211_modes[] = {
}; };
#define MAX_CUSTOM_LEN 64 #define MAX_CUSTOM_LEN 64
static inline char *ipw2100_translate_scan(struct ieee80211_device *ieee, static char *ipw2100_translate_scan(struct ieee80211_device *ieee,
char *start, char *stop, char *start, char *stop,
struct ieee80211_network *network) struct ieee80211_network *network)
{ {

View File

@ -212,7 +212,7 @@ int nfnetlink_unicast(struct sk_buff *skb, u_int32_t pid, int flags)
} }
/* Process one complete nfnetlink message. */ /* Process one complete nfnetlink message. */
static inline int nfnetlink_rcv_msg(struct sk_buff *skb, static int nfnetlink_rcv_msg(struct sk_buff *skb,
struct nlmsghdr *nlh, int *errp) struct nlmsghdr *nlh, int *errp)
{ {
struct nfnl_callback *nc; struct nfnl_callback *nc;

View File

@ -1019,7 +1019,7 @@ static inline int dentry_has_perm(struct task_struct *tsk,
has the same SID as the process. If av is zero, then has the same SID as the process. If av is zero, then
access to the file is not checked, e.g. for cases access to the file is not checked, e.g. for cases
where only the descriptor is affected like seek. */ where only the descriptor is affected like seek. */
static inline int file_has_perm(struct task_struct *tsk, static int file_has_perm(struct task_struct *tsk,
struct file *file, struct file *file,
u32 av) u32 av)
{ {

View File

@ -515,7 +515,7 @@ static inline int prog_dmabuf_adc(struct solo1_state *s)
return 0; return 0;
} }
static inline int prog_dmabuf_dac(struct solo1_state *s) static int prog_dmabuf_dac(struct solo1_state *s)
{ {
unsigned long va; unsigned long va;
int c; int c;

View File

@ -727,7 +727,7 @@ static void __apu_set_register(struct es1968 *chip, u16 channel, u8 reg, u16 dat
apu_data_set(chip, data); apu_data_set(chip, data);
} }
static inline void apu_set_register(struct es1968 *chip, u16 channel, u8 reg, u16 data) static void apu_set_register(struct es1968 *chip, u16 channel, u8 reg, u16 data)
{ {
unsigned long flags; unsigned long flags;
spin_lock_irqsave(&chip->reg_lock, flags); spin_lock_irqsave(&chip->reg_lock, flags);
@ -743,7 +743,7 @@ static u16 __apu_get_register(struct es1968 *chip, u16 channel, u8 reg)
return __maestro_read(chip, IDR0_DATA_PORT); return __maestro_read(chip, IDR0_DATA_PORT);
} }
static inline u16 apu_get_register(struct es1968 *chip, u16 channel, u8 reg) static u16 apu_get_register(struct es1968 *chip, u16 channel, u8 reg)
{ {
unsigned long flags; unsigned long flags;
u16 v; u16 v;